From 1ae9fe42b9cc807c2265d073e4ff648d46a30e71 Mon Sep 17 00:00:00 2001 From: Liang <44948473+soundOfDestiny@users.noreply.github.com> Date: Tue, 18 Oct 2022 14:41:11 +0800 Subject: [PATCH 1/3] refactor(hummock manager): lazy init `HummockVersion` and `CompactStatus` (#5863) Co-authored-by: mergify[bot] <37929162+mergify[bot]@users.noreply.github.com> --- src/meta/src/hummock/compaction_scheduler.rs | 2 +- src/meta/src/hummock/manager/mod.rs | 23 +------- src/meta/src/hummock/manager/tests.rs | 60 ++++++++++++++------ src/meta/src/hummock/test_utils.rs | 10 +++- src/meta/src/hummock/vacuum.rs | 2 +- 5 files changed, 53 insertions(+), 44 deletions(-) diff --git a/src/meta/src/hummock/compaction_scheduler.rs b/src/meta/src/hummock/compaction_scheduler.rs index 66f9097fc1b84..ecba4d7509300 100644 --- a/src/meta/src/hummock/compaction_scheduler.rs +++ b/src/meta/src/hummock/compaction_scheduler.rs @@ -344,7 +344,7 @@ mod tests { // No task let compactor = hummock_manager.get_idle_compactor().await.unwrap(); assert_eq!( - ScheduleStatus::NoTask, + ScheduleStatus::PickFailure, compaction_scheduler .pick_and_assign( StaticCompactionGroupId::StateDefault.into(), diff --git a/src/meta/src/hummock/manager/mod.rs b/src/meta/src/hummock/manager/mod.rs index b3978ccdd7362..e237a52aadfe3 100644 --- a/src/meta/src/hummock/manager/mod.rs +++ b/src/meta/src/hummock/manager/mod.rs @@ -305,18 +305,6 @@ where .collect::>(); if !compaction_statuses.is_empty() { compaction_guard.compaction_statuses = compaction_statuses; - } else { - // Initialize compact status for each compaction group - let mut compaction_statuses = - BTreeMapTransaction::new(&mut compaction_guard.compaction_statuses); - for compaction_group in self.compaction_group_manager.compaction_groups().await { - let compact_status = CompactStatus::new( - compaction_group.group_id(), - compaction_group.compaction_config().max_level, - ); - compaction_statuses.insert(compact_status.compaction_group_id(), compact_status); - } - commit_multi_var!(self, None, compaction_statuses)?; } compaction_guard.compact_task_assignment = CompactTaskAssignment::list(self.env.meta_store()) @@ -336,21 +324,12 @@ where // Insert the initial version. let mut redo_state = if versions.is_empty() { - let mut init_version = HummockVersion { + let init_version = HummockVersion { id: FIRST_VERSION_ID, levels: Default::default(), max_committed_epoch: INVALID_EPOCH, safe_epoch: INVALID_EPOCH, }; - // Initialize independent levels via corresponding compaction group' config. - for compaction_group in self.compaction_group_manager.compaction_groups().await { - init_version.levels.insert( - compaction_group.group_id(), - ::build_initial_levels( - &compaction_group.compaction_config(), - ), - ); - } init_version.insert(self.env.meta_store()).await?; init_version } else { diff --git a/src/meta/src/hummock/manager/tests.rs b/src/meta/src/hummock/manager/tests.rs index 0ded7e6766534..4c937bdbe3e43 100644 --- a/src/meta/src/hummock/manager/tests.rs +++ b/src/meta/src/hummock/manager/tests.rs @@ -22,7 +22,9 @@ use risingwave_hummock_sdk::compact::compact_task_to_string; use risingwave_hummock_sdk::compaction_group::hummock_version_ext::HummockVersionExt; use risingwave_hummock_sdk::compaction_group::StaticCompactionGroupId; // use risingwave_hummock_sdk::key_range::KeyRange; -use risingwave_hummock_sdk::{HummockContextId, HummockEpoch, HummockVersionId, FIRST_VERSION_ID}; +use risingwave_hummock_sdk::{ + CompactionGroupId, HummockContextId, HummockEpoch, HummockVersionId, FIRST_VERSION_ID, +}; use risingwave_pb::common::{HostAddress, WorkerType}; use risingwave_pb::hummock::compact_task::TaskStatus; use risingwave_pb::hummock::pin_version_response::Payload; @@ -105,6 +107,7 @@ async fn test_unpin_snapshot_before() { #[tokio::test] async fn test_hummock_compaction_task() { + use crate::hummock::error::Error; let (_, hummock_manager, _, worker_node) = setup_compute_env(80).await; let sst_num = 2; @@ -112,8 +115,15 @@ async fn test_hummock_compaction_task() { let task = hummock_manager .get_compact_task(StaticCompactionGroupId::StateDefault.into()) .await - .unwrap(); - assert_eq!(task, None); + .unwrap_err(); + if let Error::InvalidCompactionGroup(group_id) = task { + assert_eq!( + group_id, + StaticCompactionGroupId::StateDefault as CompactionGroupId + ); + } else { + panic!(); + } // Add some sstables and commit. let epoch: u64 = 1; @@ -506,10 +516,12 @@ async fn test_hummock_manager_basic() { commit_one(epoch, hummock_manager.clone()).await; epoch += 1; + let sync_group_version_id = FIRST_VERSION_ID + 1; + // increased version id assert_eq!( hummock_manager.get_current_version().await.id, - FIRST_VERSION_ID + 1 + sync_group_version_id + 1 ); // min pinned version id if no clients @@ -536,11 +548,11 @@ async fn test_hummock_manager_basic() { }; assert_eq!( version.hummock_version.as_ref().unwrap().get_id(), - FIRST_VERSION_ID + 1 + sync_group_version_id + 1 ); assert_eq!( hummock_manager.get_min_pinned_version_id().await, - FIRST_VERSION_ID + 1 + sync_group_version_id + 1 ); } @@ -557,12 +569,12 @@ async fn test_hummock_manager_basic() { }; assert_eq!( version.hummock_version.as_ref().unwrap().get_id(), - FIRST_VERSION_ID + 2 + sync_group_version_id + 2 ); // pinned by context_id_1 assert_eq!( hummock_manager.get_min_pinned_version_id().await, - FIRST_VERSION_ID + 1 + sync_group_version_id + 1 ); } @@ -577,7 +589,7 @@ async fn test_hummock_manager_basic() { ); assert_eq!( hummock_manager.proceed_version_checkpoint().await.unwrap(), - 1 + sync_group_version_id ); assert!(hummock_manager.get_ssts_to_delete().await.is_empty()); assert_eq!( @@ -585,7 +597,7 @@ async fn test_hummock_manager_basic() { .delete_version_deltas(usize::MAX) .await .unwrap(), - (1, 0) + (sync_group_version_id as usize, 0) ); hummock_manager @@ -594,7 +606,7 @@ async fn test_hummock_manager_basic() { .unwrap(); assert_eq!( hummock_manager.get_min_pinned_version_id().await, - FIRST_VERSION_ID + 2 + sync_group_version_id + 2 ); assert!(hummock_manager.get_ssts_to_delete().await.is_empty()); assert_eq!( @@ -832,7 +844,7 @@ async fn test_trigger_manual_compaction() { .await; assert_eq!( - "trigger_manual_compaction No compaction_task is available. compaction_group 2", + "Failed to get compaction task: InvalidCompactionGroup(\n 2,\n) compaction_group 2", result.err().unwrap().to_string() ); } @@ -965,8 +977,15 @@ async fn test_hummock_compaction_task_heartbeat() { let task = hummock_manager .get_compact_task(StaticCompactionGroupId::StateDefault.into()) .await - .unwrap(); - assert_eq!(task, None); + .unwrap_err(); + if let Error::InvalidCompactionGroup(group_id) = task { + assert_eq!( + group_id, + StaticCompactionGroupId::StateDefault as CompactionGroupId + ); + } else { + panic!(); + } // Add some sstables and commit. let epoch: u64 = 1; @@ -1083,8 +1102,15 @@ async fn test_hummock_compaction_task_heartbeat_removal_on_node_removal() { let task = hummock_manager .get_compact_task(StaticCompactionGroupId::StateDefault.into()) .await - .unwrap(); - assert_eq!(task, None); + .unwrap_err(); + if let Error::InvalidCompactionGroup(group_id) = task { + assert_eq!( + group_id, + StaticCompactionGroupId::StateDefault as CompactionGroupId + ); + } else { + panic!(); + } // Add some sstables and commit. let epoch: u64 = 1; @@ -1186,7 +1212,7 @@ async fn test_extend_ssts_to_delete() { // Checkpoint assert_eq!( hummock_manager.proceed_version_checkpoint().await.unwrap(), - 3 + 4 ); assert_eq!( hummock_manager diff --git a/src/meta/src/hummock/test_utils.rs b/src/meta/src/hummock/test_utils.rs index d0dbc7fe7d8b6..9b974031ff9ef 100644 --- a/src/meta/src/hummock/test_utils.rs +++ b/src/meta/src/hummock/test_utils.rs @@ -16,7 +16,6 @@ use std::sync::Arc; use std::time::Duration; use itertools::Itertools; -use risingwave_hummock_sdk::compaction_group::hummock_version_ext::HummockVersionExt; use risingwave_hummock_sdk::compaction_group::StaticCompactionGroupId; use risingwave_hummock_sdk::key::key_with_epoch; use risingwave_hummock_sdk::{ @@ -226,8 +225,13 @@ pub fn get_sorted_sstable_ids(sstables: &[SstableInfo]) -> Vec } pub fn get_sorted_committed_sstable_ids(hummock_version: &HummockVersion) -> Vec { - let levels = - hummock_version.get_compaction_group_levels(StaticCompactionGroupId::StateDefault.into()); + let levels = match hummock_version + .levels + .get(&StaticCompactionGroupId::StateDefault.into()) + { + Some(levels) => levels, + None => return vec![], + }; levels .levels .iter() diff --git a/src/meta/src/hummock/vacuum.rs b/src/meta/src/hummock/vacuum.rs index 4b4e68a821378..42eaeb8965477 100644 --- a/src/meta/src/hummock/vacuum.rs +++ b/src/meta/src/hummock/vacuum.rs @@ -356,7 +356,7 @@ mod tests { // Makes checkpoint and extends deltas_to_delete. Deletes deltas of v0->v1 and v2->v3. // Delta of v1->v2 cannot be deleted yet because it's used by ssts_to_delete. - assert_eq!(VacuumManager::vacuum_metadata(&vacuum).await.unwrap(), 2); + assert_eq!(VacuumManager::vacuum_metadata(&vacuum).await.unwrap(), 3); // No SST deletion is scheduled because no available worker. assert_eq!( VacuumManager::vacuum_sst_data(&vacuum).await.unwrap().len(), From 8a650e533cf5dd404bd6fce4e964692806ea297b Mon Sep 17 00:00:00 2001 From: ZENOTME <43447882+ZENOTME@users.noreply.github.com> Date: Tue, 18 Oct 2022 15:37:39 +0800 Subject: [PATCH 2/3] feat(pgwire):support binary format param of timestampz and interval type (#5646) * support interval,timestampz type * support binary format of timestamptz * fix binary format of interval * fix * add ut Co-authored-by: mergify[bot] <37929162+mergify[bot]@users.noreply.github.com> --- Cargo.lock | 13 ++++ src/common/src/types/interval.rs | 42 +++++++++++- src/common/src/types/mod.rs | 2 +- src/expr/Cargo.toml | 1 + src/expr/src/vector_op/cast.rs | 14 ++++ src/frontend/src/handler/util.rs | 9 ++- src/utils/pgwire/Cargo.toml | 1 + src/utils/pgwire/src/pg_extended.rs | 76 ++++++++++++++------- src/utils/pgwire/src/pg_field_descriptor.rs | 18 ++--- 9 files changed, 138 insertions(+), 38 deletions(-) diff --git a/Cargo.lock b/Cargo.lock index 857ee6b4237fb..2e28ef4ffe20e 100644 --- a/Cargo.lock +++ b/Cargo.lock @@ -3857,6 +3857,17 @@ dependencies = [ "indexmap", ] +[[package]] +name = "pg_interval" +version = "0.4.1" +source = "registry+https://github.com/rust-lang/crates.io-index" +checksum = "47354dbd658c57a5ee1cc97a79937345170234d4c817768de80ea6d2e9f5b98a" +dependencies = [ + "bytes", + "chrono", + "postgres-types", +] + [[package]] name = "pgwire" version = "0.2.0-alpha" @@ -3870,6 +3881,7 @@ dependencies = [ "itertools", "madsim-tokio", "openssl", + "pg_interval", "postgres-types", "regex", "rust_decimal", @@ -5017,6 +5029,7 @@ dependencies = [ "num-traits", "parse-display", "paste", + "postgres-types", "prost", "regex", "risingwave_common", diff --git a/src/common/src/types/interval.rs b/src/common/src/types/interval.rs index 4e4c34e2e0777..89a1e242b9638 100644 --- a/src/common/src/types/interval.rs +++ b/src/common/src/types/interval.rs @@ -13,15 +13,17 @@ // limitations under the License. use std::cmp::Ordering; +use std::error::Error; use std::fmt::{Display, Formatter, Write as _}; use std::hash::{Hash, Hasher}; use std::io::Write; use std::ops::{Add, Neg, Sub}; use anyhow::anyhow; -use byteorder::{BigEndian, WriteBytesExt}; +use byteorder::{BigEndian, NetworkEndian, ReadBytesExt, WriteBytesExt}; use bytes::BytesMut; use num_traits::{CheckedAdd, CheckedSub, Zero}; +use postgres_types::{to_sql_checked, FromSql}; use risingwave_pb::data::IntervalUnit as IntervalUnitProto; use smallvec::SmallVec; @@ -481,6 +483,44 @@ impl Display for IntervalUnit { } } +impl ToSql for IntervalUnit { + to_sql_checked!(); + + fn to_sql( + &self, + _: &Type, + out: &mut BytesMut, + ) -> std::result::Result> { + // refer: https://github.com/postgres/postgres/blob/517bf2d91/src/backend/utils/adt/timestamp.c#L1008 + out.put_i64(self.ms * 1000); + out.put_i32(self.days); + out.put_i32(self.months); + Ok(IsNull::No) + } + + fn accepts(ty: &Type) -> bool { + matches!(*ty, Type::INTERVAL) + } +} + +impl<'a> FromSql<'a> for IntervalUnit { + fn from_sql( + _: &Type, + mut raw: &'a [u8], + ) -> std::result::Result> { + let micros = raw.read_i64::()?; + let days = raw.read_i32::()?; + let months = raw.read_i32::()?; + // TODO: https://github.com/risingwavelabs/risingwave/issues/4514 + // Only support ms now. + Ok(IntervalUnit::new(months, days, micros / 1000)) + } + + fn accepts(ty: &Type) -> bool { + matches!(*ty, Type::INTERVAL) + } +} + #[derive(Debug, Clone, PartialEq, Eq, Hash)] pub enum DateTimeField { Year, diff --git a/src/common/src/types/mod.rs b/src/common/src/types/mod.rs index d2de9c190b855..53d23f0e6176c 100644 --- a/src/common/src/types/mod.rs +++ b/src/common/src/types/mod.rs @@ -763,7 +763,7 @@ impl ScalarRefImpl<'_> { Self::NaiveTime(v) => v.0.to_sql(ty, &mut output).unwrap(), Self::Struct(_) => todo!("Don't support struct serialization yet"), Self::List(_) => todo!("Don't support list serialization yet"), - Self::Interval(_) => todo!("Don't support interval serialization yet"), + Self::Interval(v) => v.to_sql(ty, &mut output).unwrap(), }; output.freeze() } diff --git a/src/expr/Cargo.toml b/src/expr/Cargo.toml index 76f8596669b11..030a311f106bf 100644 --- a/src/expr/Cargo.toml +++ b/src/expr/Cargo.toml @@ -21,6 +21,7 @@ memcomparable = { path = "../utils/memcomparable" } num-traits = "0.2" parse-display = "0.6" paste = "1" +postgres-types = { version = "0.2.4", features = ["derive","with-chrono-0_4"] } prost = "0.11" regex = "1" risingwave_common = { path = "../common" } diff --git a/src/expr/src/vector_op/cast.rs b/src/expr/src/vector_op/cast.rs index 9b9cb204ba2c6..d97fe058d902f 100644 --- a/src/expr/src/vector_op/cast.rs +++ b/src/expr/src/vector_op/cast.rs @@ -15,8 +15,10 @@ use std::any::type_name; use std::str::FromStr; +use bytes::{Bytes, BytesMut}; use chrono::{DateTime, NaiveDate, NaiveDateTime, NaiveTime, TimeZone, Utc}; use num_traits::ToPrimitive; +use postgres_types::ToSql; use risingwave_common::array::{Array, ListRef, ListValue}; use risingwave_common::types::{ DataType, Decimal, IntervalUnit, NaiveDateTimeWrapper, NaiveDateWrapper, NaiveTimeWrapper, @@ -115,6 +117,18 @@ pub fn timestampz_to_utc_string(elem: i64) -> String { instant.format("%Y-%m-%d %H:%M:%S%.f%:z").to_string() } +pub fn timestampz_to_utc_binary(elem: i64) -> Bytes { + // Just a meaningful representation as placeholder. The real implementation depends on TimeZone + // from session. See #3552. + let instant = Utc.timestamp_nanos(elem * 1000); + let mut out = BytesMut::new(); + // postgres_types::Type::ANY is only used as a placeholder. + instant + .to_sql(&postgres_types::Type::ANY, &mut out) + .unwrap(); + out.freeze() +} + #[inline(always)] pub fn str_parse(elem: &str) -> Result where diff --git a/src/frontend/src/handler/util.rs b/src/frontend/src/handler/util.rs index 8f62eb8b66d00..13b8390ed7f76 100644 --- a/src/frontend/src/handler/util.rs +++ b/src/frontend/src/handler/util.rs @@ -26,7 +26,7 @@ use pin_project_lite::pin_project; use risingwave_common::array::DataChunk; use risingwave_common::catalog::{ColumnDesc, Field}; use risingwave_common::types::{DataType, ScalarRefImpl}; -use risingwave_expr::vector_op::cast::timestampz_to_utc_string; +use risingwave_expr::vector_op::cast::{timestampz_to_utc_binary, timestampz_to_utc_string}; pin_project! { /// Wrapper struct that converts a stream of DataChunk to a stream of RowSet based on formatting @@ -92,7 +92,10 @@ fn pg_value_format(data_type: &DataType, d: ScalarRefImpl<'_>, format: bool) -> _ => d.to_string().into(), } } else { - d.binary_serialize() + match (data_type, d) { + (DataType::Timestampz, ScalarRefImpl::Int64(us)) => timestampz_to_utc_binary(us), + _ => d.binary_serialize(), + } } } @@ -147,7 +150,7 @@ pub fn data_type_to_type_oid(data_type: DataType) -> TypeOid { DataType::Date => TypeOid::Date, DataType::Time => TypeOid::Time, DataType::Timestamp => TypeOid::Timestamp, - DataType::Timestampz => TypeOid::Timestampz, + DataType::Timestampz => TypeOid::Timestamptz, DataType::Decimal => TypeOid::Decimal, DataType::Interval => TypeOid::Interval, DataType::Struct { .. } => TypeOid::Varchar, diff --git a/src/utils/pgwire/Cargo.toml b/src/utils/pgwire/Cargo.toml index 09089c543f6ec..c0f2fdc7bfbf0 100644 --- a/src/utils/pgwire/Cargo.toml +++ b/src/utils/pgwire/Cargo.toml @@ -13,6 +13,7 @@ chrono = { version = "0.4", default-features = false, features = ["clock", "std" futures = { version = "0.3", default-features = false, features = ["alloc"] } itertools = "0.10" openssl = "0.10.3" +pg_interval = "0.4" postgres-types = { version = "0.2.4", features = ["derive","with-chrono-0_4"] } regex = "1.5" rust_decimal = { version = "1", features = ["db-tokio-postgres"] } diff --git a/src/utils/pgwire/src/pg_extended.rs b/src/utils/pgwire/src/pg_extended.rs index f62e3627f2fd6..577c68eb2f97a 100644 --- a/src/utils/pgwire/src/pg_extended.rs +++ b/src/utils/pgwire/src/pg_extended.rs @@ -362,6 +362,11 @@ impl PreparedStatement { raw_params: &[Bytes], param_format: bool, ) -> PsqlResult> { + if type_description.len() != raw_params.len() { + return Err(PsqlError::BindError( + "The number of params doesn't match the number of types".into(), + )); + } assert_eq!(type_description.len(), raw_params.len()); let mut params = Vec::with_capacity(raw_params.len()); @@ -462,25 +467,25 @@ impl PreparedStatement { }; format!("{}::DECIMAL", tmp) } - TypeOid::Timestampz => { - if param_format { - return Err(PsqlError::BindError( - "Can't support Timestampz type in binary format".into(), - )); + TypeOid::Timestamptz => { + let tmp = if param_format { + chrono::DateTime::::from_sql(&place_hodler, raw_param) + .unwrap() + .to_string() } else { - let tmp = cstr_to_str(raw_param).unwrap().to_string(); - format!("'{}'::TIMESTAMPZ", tmp) - } + cstr_to_str(raw_param).unwrap().to_string() + }; + format!("'{}'::TIMESTAMPTZ", tmp) } TypeOid::Interval => { - if param_format { - return Err(PsqlError::BindError( - "Can't support Interval type in binary format".into(), - )); + let tmp = if param_format { + pg_interval::Interval::from_sql(&place_hodler, raw_param) + .unwrap() + .to_postgres() } else { - let tmp = cstr_to_str(raw_param).unwrap().to_string(); - format!("'{}'::INTERVAL", tmp) - } + cstr_to_str(raw_param).unwrap().to_string() + }; + format!("'{}'::INTERVAL", tmp) } }; params.push(str) @@ -506,16 +511,10 @@ impl PreparedStatement { TypeOid::Time => params.push("'00:00:00'::TIME".to_string()), TypeOid::Timestamp => params.push("'2021-01-01 00:00:00'::TIMESTAMP".to_string()), TypeOid::Decimal => params.push("'0'::DECIMAL".to_string()), - TypeOid::Timestampz => { - return Err(PsqlError::ParseError( - "Can't support Timestampz type in extended query mode".into(), - )) - } - TypeOid::Interval => { - return Err(PsqlError::ParseError( - "Can't support Interval type in extended query mode".into(), - )) + TypeOid::Timestamptz => { + params.push("'2022-10-01 12:00:00+01:00'::timestamptz".to_string()) } + TypeOid::Interval => params.push("'2 months ago'::interval".to_string()), }; } Ok(params) @@ -554,6 +553,8 @@ impl PreparedStatement { #[cfg(test)] mod tests { + use chrono::{DateTime, NaiveDateTime, Utc}; + use pg_interval::Interval; // Note this useful idiom: importing names from outer (for mod tests) scope. use postgres_types::private::BytesMut; use tokio_postgres::types::{ToSql, Type}; @@ -734,15 +735,18 @@ mod tests { ] ); } + #[test] fn test_parse_params_binary() { let place_hodler = Type::ANY; + // Test VACHAR type. let raw_params = vec!["A".into(), "B".into(), "C".into()]; let type_description = vec![TypeOid::Varchar; 3]; let params = PreparedStatement::parse_params(&type_description, &raw_params, true).unwrap(); assert_eq!(params, vec!["'A'", "'B'", "'C'"]); + // Test BOOLEAN type. let mut raw_params = vec![BytesMut::new(); 2]; false.to_sql(&place_hodler, &mut raw_params[0]).unwrap(); true.to_sql(&place_hodler, &mut raw_params[1]).unwrap(); @@ -754,6 +758,7 @@ mod tests { let params = PreparedStatement::parse_params(&type_description, &raw_params, true).unwrap(); assert_eq!(params, vec!["false", "true"]); + // Test SMALLINT, INT, BIGINT type. let mut raw_params = vec![BytesMut::new(); 3]; 1_i16.to_sql(&place_hodler, &mut raw_params[0]).unwrap(); 2_i32.to_sql(&place_hodler, &mut raw_params[1]).unwrap(); @@ -766,6 +771,7 @@ mod tests { let params = PreparedStatement::parse_params(&type_description, &raw_params, true).unwrap(); assert_eq!(params, vec!["1::SMALLINT", "2::INT", "3::BIGINT"]); + // Test FLOAT4, FLOAT8, DECIMAL type. let mut raw_params = vec![BytesMut::new(); 3]; 1.0_f32.to_sql(&place_hodler, &mut raw_params[0]).unwrap(); 2.0_f64.to_sql(&place_hodler, &mut raw_params[1]).unwrap(); @@ -781,6 +787,7 @@ mod tests { let params = PreparedStatement::parse_params(&type_description, &raw_params, true).unwrap(); assert_eq!(params, vec!["1::FLOAT4", "2::FLOAT8", "3::DECIMAL"]); + // Test DATE, TIME, TIMESTAMP type. let mut raw_params = vec![BytesMut::new(); 3]; chrono::NaiveDate::from_ymd(2021, 1, 1) .to_sql(&place_hodler, &mut raw_params[0]) @@ -805,5 +812,26 @@ mod tests { "'2021-01-07 06:13:20'::TIMESTAMP" ] ); + + // Test TIMESTAMPTZ, INTERVAL type. + let mut raw_params = vec![BytesMut::new(); 2]; + DateTime::::from_utc(NaiveDateTime::from_timestamp(1200, 0), Utc) + .to_sql(&place_hodler, &mut raw_params[0]) + .unwrap(); + let interval = Interval::new(1, 1, 24000000); + ToSql::to_sql(&interval, &place_hodler, &mut raw_params[1]).unwrap(); + let raw_params = raw_params + .into_iter() + .map(|b| b.freeze()) + .collect::>(); + let type_description = vec![TypeOid::Timestamptz, TypeOid::Interval]; + let params = PreparedStatement::parse_params(&type_description, &raw_params, true).unwrap(); + assert_eq!( + params, + vec![ + "'1970-01-01 00:20:00 UTC'::TIMESTAMPTZ", + "'1 mons 1 days 00:00:24'::INTERVAL" + ] + ); } } diff --git a/src/utils/pgwire/src/pg_field_descriptor.rs b/src/utils/pgwire/src/pg_field_descriptor.rs index 534e768e6a537..8a86fed7bee8d 100644 --- a/src/utils/pgwire/src/pg_field_descriptor.rs +++ b/src/utils/pgwire/src/pg_field_descriptor.rs @@ -45,7 +45,7 @@ impl PgFieldDescriptor { | TypeOid::Float8 | TypeOid::Timestamp | TypeOid::Time - | TypeOid::Timestampz => 8, + | TypeOid::Timestamptz => 8, TypeOid::SmallInt => 2, TypeOid::Varchar | TypeOid::Decimal | TypeOid::Interval => -1, }; @@ -102,7 +102,7 @@ pub enum TypeOid { Date, Time, Timestamp, - Timestampz, + Timestamptz, Decimal, Interval, } @@ -126,9 +126,9 @@ impl TypeOid { 1082 => Ok(TypeOid::Date), 1083 => Ok(TypeOid::Time), 1114 => Ok(TypeOid::Timestamp), - 1184 => Ok(TypeOid::Timestampz), + 1184 => Ok(TypeOid::Timestamptz), 1700 => Ok(TypeOid::Decimal), - 2201 => Ok(TypeOid::Interval), + 1186 => Ok(TypeOid::Interval), v => Err(TypeOidError(v)), } } @@ -151,7 +151,7 @@ impl TypeOid { TypeOid::Date => 1082, TypeOid::Time => 1083, TypeOid::Timestamp => 1114, - TypeOid::Timestampz => 1184, + TypeOid::Timestamptz => 1184, TypeOid::Decimal => 1700, TypeOid::Interval => 1186, } @@ -164,9 +164,9 @@ impl FromStr for TypeOid { fn from_str(s: &str) -> Result { let s = s.to_ascii_lowercase(); match s.as_str() { - "boolean" => Ok(TypeOid::Boolean), - "bigint" => Ok(TypeOid::BigInt), - "smallint" => Ok(TypeOid::SmallInt), + "bool" | "boolean" => Ok(TypeOid::Boolean), + "bigint" | "int8" => Ok(TypeOid::BigInt), + "smallint" | "int2" => Ok(TypeOid::SmallInt), "int" | "int4" => Ok(TypeOid::Int), "float4" => Ok(TypeOid::Float4), "float8" => Ok(TypeOid::Float8), @@ -174,7 +174,7 @@ impl FromStr for TypeOid { "date" => Ok(TypeOid::Date), "time" => Ok(TypeOid::Time), "timestamp" => Ok(TypeOid::Timestamp), - "timestampz" => Ok(TypeOid::Timestampz), + "timestamptz" => Ok(TypeOid::Timestamptz), "decimal" => Ok(TypeOid::Decimal), "interval" => Ok(TypeOid::Interval), _ => Err(TypeOidError(0)), From f4e447500d7f4b09f498a56f02a4c8a65d2b18d6 Mon Sep 17 00:00:00 2001 From: nanderstabel Date: Tue, 18 Oct 2022 02:54:50 -0500 Subject: [PATCH 3/3] test: Add CH-benCHmark queries (#5600) * add q02 * add q02 and q19 * remove tpcc_ prefix * add q12 * Add q11 and q17 * commit * add transactions * add q03 * add q04 * remove * add more queries * fix * create output for q17 Co-authored-by: mergify[bot] <37929162+mergify[bot]@users.noreply.github.com> --- e2e_test/ch-benchmark/ch_benchmark.slt | 59 +- e2e_test/ch-benchmark/create_sources.slt.part | 36 +- e2e_test/ch-benchmark/drop_sources.slt.part | 18 +- e2e_test/ch-benchmark/q01.slt.part | 17 + e2e_test/ch-benchmark/q02.slt.part | 22 + e2e_test/ch-benchmark/q03.slt.part | 36 + e2e_test/ch-benchmark/q04.slt.part | 23 + e2e_test/ch-benchmark/q06.slt.part | 8 + e2e_test/ch-benchmark/q09.slt.part | 16 + e2e_test/ch-benchmark/q10.slt.part | 35 + e2e_test/ch-benchmark/q11.slt.part | 16 + e2e_test/ch-benchmark/q12.slt.part | 21 + e2e_test/ch-benchmark/q13.slt.part | 11 +- e2e_test/ch-benchmark/q15.slt.part | 15 + e2e_test/ch-benchmark/q16.slt.part | 1600 ++++++++++++++-- e2e_test/ch-benchmark/q17.slt.part | 11 + e2e_test/ch-benchmark/q18.slt.part | 37 + e2e_test/ch-benchmark/q20.slt.part | 19 + e2e_test/ch-benchmark/q21.slt.part | 22 + e2e_test/ch-benchmark/q22.slt.part | 21 + e2e_test/tpch/insert_supplier.slt.part | 14 +- .../test_data/{tpcc_customer.1 => customer.1} | 275 +-- scripts/source/test_data/district.1 | 80 + scripts/source/test_data/item.1 | 1500 +++++++++++++++ .../test_data/{tpcc_neworder.1 => neworder.1} | 247 +-- scripts/source/test_data/orderline.1 | 750 ++++++++ .../test_data/{tpcc_orders.1 => orders.1} | 287 +-- scripts/source/test_data/stock.1 | 1601 +++++++++++++++++ scripts/source/test_data/tpcc_district.1 | 12 - scripts/source/test_data/tpcc_item.1 | 100 - scripts/source/test_data/tpcc_orderline.1 | 335 ---- scripts/source/test_data/tpcc_stock.1 | 110 -- scripts/source/test_data/tpcc_warehouse.1 | 1 - scripts/source/test_data/warehouse.1 | 51 + 34 files changed, 6391 insertions(+), 1015 deletions(-) create mode 100644 e2e_test/ch-benchmark/q01.slt.part create mode 100644 e2e_test/ch-benchmark/q02.slt.part create mode 100644 e2e_test/ch-benchmark/q03.slt.part create mode 100644 e2e_test/ch-benchmark/q04.slt.part create mode 100644 e2e_test/ch-benchmark/q06.slt.part create mode 100644 e2e_test/ch-benchmark/q09.slt.part create mode 100644 e2e_test/ch-benchmark/q10.slt.part create mode 100644 e2e_test/ch-benchmark/q11.slt.part create mode 100644 e2e_test/ch-benchmark/q12.slt.part create mode 100644 e2e_test/ch-benchmark/q15.slt.part create mode 100644 e2e_test/ch-benchmark/q17.slt.part create mode 100644 e2e_test/ch-benchmark/q18.slt.part create mode 100644 e2e_test/ch-benchmark/q20.slt.part create mode 100644 e2e_test/ch-benchmark/q21.slt.part create mode 100644 e2e_test/ch-benchmark/q22.slt.part rename scripts/source/test_data/{tpcc_customer.1 => customer.1} (54%) create mode 100644 scripts/source/test_data/district.1 create mode 100644 scripts/source/test_data/item.1 rename scripts/source/test_data/{tpcc_neworder.1 => neworder.1} (73%) create mode 100644 scripts/source/test_data/orderline.1 rename scripts/source/test_data/{tpcc_orders.1 => orders.1} (53%) create mode 100644 scripts/source/test_data/stock.1 delete mode 100644 scripts/source/test_data/tpcc_district.1 delete mode 100644 scripts/source/test_data/tpcc_item.1 delete mode 100644 scripts/source/test_data/tpcc_orderline.1 delete mode 100644 scripts/source/test_data/tpcc_stock.1 delete mode 100644 scripts/source/test_data/tpcc_warehouse.1 create mode 100644 scripts/source/test_data/warehouse.1 diff --git a/e2e_test/ch-benchmark/ch_benchmark.slt b/e2e_test/ch-benchmark/ch_benchmark.slt index 8851900ce7818..40f5e3cbffd9a 100644 --- a/e2e_test/ch-benchmark/ch_benchmark.slt +++ b/e2e_test/ch-benchmark/ch_benchmark.slt @@ -1,13 +1,66 @@ -include ./create_sources.slt.part +# Create tpch tables include ../tpch/create_tables.slt.part +# Drop unneeded tables +statement ok +DROP TABLE lineitem; + +statement ok +DROP TABLE orders; + +statement ok +DROP TABLE customer; + +statement ok +DROP TABLE partsupp; + +statement ok +DROP TABLE part; + +# Insert data to tpch tables +include ../tpch/insert_nation.slt.part +include ../tpch/insert_region.slt.part +include ../tpch/insert_supplier.slt.part + +# Create materialized sources from tpcc tables +include ./create_sources.slt.part + # Ensure that the upstream data is fully consumed statement ok flush; -# include ./q01.slt.part --> precision error +# Run CH-benCHmark queries +include ./q01.slt.part +include ./q02.slt.part +include ./q03.slt.part +include ./q04.slt.part +# include ./q05.slt.part --> no output +include ./q06.slt.part +# include ./q07.slt.part --> no output +# include ./q08.slt.part --> no output +include ./q09.slt.part +include ./q10.slt.part +include ./q11.slt.part +include ./q12.slt.part include ./q13.slt.part +# include ./q14.slt.part --> panic, see issue: https://github.com/risingwavelabs/risingwave/issues/5563 +include ./q15.slt.part include ./q16.slt.part +include ./q17.slt.part +include ./q18.slt.part +# include ./q19.slt.part --> precision error +include ./q20.slt.part +include ./q21.slt.part +include ./q22.slt.part include ./drop_sources.slt.part -include ../tpch/drop_tables.slt.part + +# Drop tpch tables +statement ok +DROP TABLE supplier; + +statement ok +DROP TABLE region; + +statement ok +DROP TABLE nation; diff --git a/e2e_test/ch-benchmark/create_sources.slt.part b/e2e_test/ch-benchmark/create_sources.slt.part index ac4352aca769b..a0582c53e39ae 100644 --- a/e2e_test/ch-benchmark/create_sources.slt.part +++ b/e2e_test/ch-benchmark/create_sources.slt.part @@ -1,5 +1,5 @@ statement ok -CREATE MATERIALIZED SOURCE tpcc_customer ( +CREATE MATERIALIZED SOURCE customer ( c_id INTEGER, c_d_id INTEGER, c_w_id INTEGER, @@ -25,13 +25,13 @@ CREATE MATERIALIZED SOURCE tpcc_customer ( PRIMARY KEY (c_id, c_d_id, c_w_id) ) with ( connector = 'kafka', - topic = 'tpcc_customer', + topic = 'customer', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; statement ok -CREATE MATERIALIZED SOURCE tpcc_district ( +CREATE MATERIALIZED SOURCE district ( d_id INTEGER, d_w_id INTEGER, d_name VARCHAR, @@ -46,13 +46,13 @@ CREATE MATERIALIZED SOURCE tpcc_district ( PRIMARY KEY (d_id, d_w_id) ) with ( connector = 'kafka', - topic = 'tpcc_district', + topic = 'district', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; # statement ok -# CREATE MATERIALIZED SOURCE tpcc_history ( +# CREATE MATERIALIZED SOURCE history ( # h_c_id INTEGER, # h_c_d_id INTEGER, # h_c_w_id INTEGER, @@ -63,13 +63,13 @@ CREATE MATERIALIZED SOURCE tpcc_district ( # h_data VARCHAR # ) with ( # connector = 'kafka', -# topic = 'tpcc_history', +# topic = 'history', # properties.bootstrap.server = '127.0.0.1:29092', # scan.startup.mode = 'earliest' # ) ROW FORMAT DEBEZIUM_JSON; statement ok -CREATE MATERIALIZED SOURCE tpcc_item ( +CREATE MATERIALIZED SOURCE item ( i_id INTEGER, i_im_id INTEGER, i_name VARCHAR, @@ -78,26 +78,26 @@ CREATE MATERIALIZED SOURCE tpcc_item ( PRIMARY KEY (i_id) ) with ( connector = 'kafka', - topic = 'tpcc_item', + topic = 'item', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; statement ok -CREATE MATERIALIZED SOURCE tpcc_neworder ( +CREATE MATERIALIZED SOURCE neworder ( no_o_id INTEGER, no_d_id INTEGER, no_w_id INTEGER, PRIMARY KEY (no_o_id, no_d_id, no_w_id) ) with ( connector = 'kafka', - topic = 'tpcc_neworder', + topic = 'neworder', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; statement ok -CREATE MATERIALIZED SOURCE tpcc_orderline ( +CREATE MATERIALIZED SOURCE orderline ( ol_o_id INTEGER, ol_d_id INTEGER, ol_w_id INTEGER, @@ -111,13 +111,13 @@ CREATE MATERIALIZED SOURCE tpcc_orderline ( PRIMARY KEY (ol_o_id, ol_d_id, ol_w_id, ol_number) ) with ( connector = 'kafka', - topic = 'tpcc_orderline', + topic = 'orderline', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; statement ok -CREATE MATERIALIZED SOURCE tpcc_orders ( +CREATE MATERIALIZED SOURCE orders ( o_id INTEGER, o_d_id INTEGER, o_w_id INTEGER, @@ -129,13 +129,13 @@ CREATE MATERIALIZED SOURCE tpcc_orders ( PRIMARY KEY (o_id, o_d_id, o_w_id) ) with ( connector = 'kafka', - topic = 'tpcc_orders', + topic = 'orders', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; statement ok -CREATE MATERIALIZED SOURCE tpcc_stock ( +CREATE MATERIALIZED SOURCE stock ( st_i_id INTEGER, st_w_id INTEGER, st_quantity INTEGER, @@ -156,13 +156,13 @@ CREATE MATERIALIZED SOURCE tpcc_stock ( PRIMARY KEY (st_i_id, st_w_id) ) with ( connector = 'kafka', - topic = 'tpcc_stock', + topic = 'stock', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; statement ok -CREATE MATERIALIZED SOURCE tpcc_warehouse ( +CREATE MATERIALIZED SOURCE warehouse ( w_id INTEGER, w_name VARCHAR, w_street_1 VARCHAR, @@ -175,7 +175,7 @@ CREATE MATERIALIZED SOURCE tpcc_warehouse ( PRIMARY KEY (w_id) ) with ( connector = 'kafka', - topic = 'tpcc_warehouse', + topic = 'warehouse', properties.bootstrap.server = '127.0.0.1:29092', scan.startup.mode = 'earliest' ) ROW FORMAT DEBEZIUM_JSON; diff --git a/e2e_test/ch-benchmark/drop_sources.slt.part b/e2e_test/ch-benchmark/drop_sources.slt.part index 1a6e93514ee85..9ecf312d051ea 100644 --- a/e2e_test/ch-benchmark/drop_sources.slt.part +++ b/e2e_test/ch-benchmark/drop_sources.slt.part @@ -1,26 +1,26 @@ statement ok -DROP SOURCE tpcc_customer; +DROP SOURCE customer; statement ok -DROP SOURCE tpcc_district; +DROP SOURCE district; # statement ok -# DROP SOURCE tpcc_history; +# DROP SOURCE history; statement ok -DROP SOURCE tpcc_item; +DROP SOURCE item; statement ok -DROP SOURCE tpcc_neworder; +DROP SOURCE neworder; statement ok -DROP SOURCE tpcc_orderline; +DROP SOURCE orderline; statement ok -DROP SOURCE tpcc_orders; +DROP SOURCE orders; statement ok -DROP SOURCE tpcc_stock; +DROP SOURCE stock; statement ok -DROP SOURCE tpcc_warehouse; +DROP SOURCE warehouse; diff --git a/e2e_test/ch-benchmark/q01.slt.part b/e2e_test/ch-benchmark/q01.slt.part new file mode 100644 index 0000000000000..964894ade6c6c --- /dev/null +++ b/e2e_test/ch-benchmark/q01.slt.part @@ -0,0 +1,17 @@ +query IIIIII rowsort +select ol_number, + sum(ol_quantity) as sum_qty, + sum(ol_amount) as sum_amount, + avg(ol_quantity) as avg_qty, + avg(ol_amount) as avg_amount, + count(*) as count_order +from orderline +where ol_delivery_d > '2007-01-02 00:00:00.000000' +group by ol_number order by ol_number; +---- + 1 600 84 5 0.7 120 + 2 550 0 5 0 110 + 3 560 14739 5.0909090909090909090909090909 133.9909090909091 110 + 4 550 44.1 5 0.4009090770374645 110 + 5 550 0 5 0 110 + 6 200 0 5 0 40 diff --git a/e2e_test/ch-benchmark/q02.slt.part b/e2e_test/ch-benchmark/q02.slt.part new file mode 100644 index 0000000000000..02410574e64f7 --- /dev/null +++ b/e2e_test/ch-benchmark/q02.slt.part @@ -0,0 +1,22 @@ +query ITTITTTT rowsort +select s_suppkey, s_name, n_name, i_id, i_name, s_address, s_phone, s_comment +from item, supplier, stock, nation, region, + (select st_i_id as m_i_id, + min(st_quantity) as m_st_quantity + from stock, supplier, nation, region + where (st_w_id*st_i_id) % 10000=s_suppkey + and s_nationkey=n_nationkey + and n_regionkey=r_regionkey + and r_name like 'EUROP%' + group by st_i_id) m +where i_id = st_i_id + and (st_w_id * st_i_id) % 10000 = s_suppkey + and s_nationkey = n_nationkey + and n_regionkey = r_regionkey + and i_data like '%B' + and r_name like 'EUROP%' + and i_id=m_i_id + and st_quantity = m_st_quantity +order by n_name, s_name, i_id; +---- +11 Supplier#000000011 GERMANY 11 t4ccklaRBqjFXhCnH JfwTs,LZrV, M,9C 28-613-996-1505 y ironic packages. slyly ironic accounts affix furiously; ironically unusual excuses across the flu diff --git a/e2e_test/ch-benchmark/q03.slt.part b/e2e_test/ch-benchmark/q03.slt.part new file mode 100644 index 0000000000000..53c2653a43eb8 --- /dev/null +++ b/e2e_test/ch-benchmark/q03.slt.part @@ -0,0 +1,36 @@ +query IIIIT rowsort +select ol_o_id, ol_w_id, ol_d_id, + sum(ol_amount) as revenue, o_entry_d +from customer, neworder, orders, orderline +where c_state like 'A%' + and c_id = o_c_id + and c_w_id = o_w_id + and c_d_id = o_d_id + and no_w_id = o_w_id + and no_d_id = o_d_id + and no_o_id = o_id + and ol_w_id = o_w_id + and ol_d_id = o_d_id + and ol_o_id = o_id + and o_entry_d > '2007-01-02 00:00:00.000000' +group by ol_o_id, ol_w_id, ol_d_id, o_entry_d +order by revenue desc, o_entry_d; +---- + 2111 1 4 21 2015-11-22 00:00:00 + 2107 1 4 0 2015-11-22 00:00:00 + 2105 1 7 0 2015-11-22 00:00:00 + 2112 1 2 0 2015-11-22 00:00:00 + 2106 1 9 0 2015-11-22 00:00:00 + 2108 1 6 0 2015-11-22 00:00:00 + 2108 1 2 0 2015-11-22 00:00:00 + 2109 1 4 0 2015-11-22 00:00:00 + 2112 1 8 0 2015-11-22 00:00:00 + 2114 1 4 0 2015-11-22 00:00:00 + 2110 1 7 0 2015-11-22 00:00:00 + 2107 1 8 0 2015-11-22 00:00:00 + 2113 1 2 0 2015-11-22 00:00:00 + 2106 1 4 0 2015-11-22 00:00:00 + 2111 1 9 0 2015-11-22 00:00:00 + 2112 1 4 0 2015-11-22 00:00:00 + 2107 1 2 0 2015-11-22 00:00:00 + 2113 1 6 0 2015-11-22 00:00:00 diff --git a/e2e_test/ch-benchmark/q04.slt.part b/e2e_test/ch-benchmark/q04.slt.part new file mode 100644 index 0000000000000..76fffcca606d3 --- /dev/null +++ b/e2e_test/ch-benchmark/q04.slt.part @@ -0,0 +1,23 @@ +query II rowsort +select o_ol_cnt, count(*) as order_count +from orders +where o_entry_d >= '2007-01-02 00:00:00.000000' + and o_entry_d < '2017-01-02 00:00:00.000000' + and exists (select * + from orderline + where o_id = ol_o_id + and o_w_id = ol_w_id + and o_d_id = ol_d_id + and ol_delivery_d >= o_entry_d) +group by o_ol_cnt +order by o_ol_cnt; +---- + 5 10 + 6 14 + 7 14 + 8 16 + 9 16 +10 10 +11 12 +12 6 +13 2 diff --git a/e2e_test/ch-benchmark/q06.slt.part b/e2e_test/ch-benchmark/q06.slt.part new file mode 100644 index 0000000000000..8d4f43b45100a --- /dev/null +++ b/e2e_test/ch-benchmark/q06.slt.part @@ -0,0 +1,8 @@ +query R rowsort +select sum(ol_amount) as revenue +from orderline +where ol_delivery_d >= '1999-01-01 00:00:00.000000' + and ol_delivery_d < '2020-01-01 00:00:00.000000' + and ol_quantity between 1 and 100000; +---- +5446.26 diff --git a/e2e_test/ch-benchmark/q09.slt.part b/e2e_test/ch-benchmark/q09.slt.part new file mode 100644 index 0000000000000..b671a21d6084f --- /dev/null +++ b/e2e_test/ch-benchmark/q09.slt.part @@ -0,0 +1,16 @@ +query TTR rowsort +select n_name, extract(year from o_entry_d::timestamp) as l_year, sum(ol_amount) as sum_profit +from item, stock, supplier, orderline, orders, nation +where ol_i_id = st_i_id + and ol_supply_w_id = st_w_id + and (st_w_id * st_i_id) % 10000 = s_suppkey + and ol_w_id = o_w_id + and ol_d_id = o_d_id + and ol_o_id = o_id + and ol_i_id = i_id + and s_nationkey = n_nationkey + and i_data like '%BB' +group by n_name, extract(year from o_entry_d::timestamp) +order by n_name, l_year desc; +---- + GERMANY 2015 0 diff --git a/e2e_test/ch-benchmark/q10.slt.part b/e2e_test/ch-benchmark/q10.slt.part new file mode 100644 index 0000000000000..dfac8b7a986ff --- /dev/null +++ b/e2e_test/ch-benchmark/q10.slt.part @@ -0,0 +1,35 @@ +query ITRTTT rowsort +select c_id, c_last, sum(ol_amount) as revenue, c_city, c_phone, n_name +from customer, orders, orderline, nation +where c_id = o_c_id + and c_w_id = o_w_id + and c_d_id = o_d_id + and ol_w_id = o_w_id + and ol_d_id = o_d_id + and ol_o_id = o_id + and o_entry_d >= '2007-01-02 00:00:00.000000' + and o_entry_d <= ol_delivery_d + and n_nationkey = ascii(substr(c_state,1,1)) - 48 +group by c_id, c_last, c_city, c_phone, n_name +order by revenue desc; +---- + 9 BARBARATION 998 Bgyigg02R06By 766-299-8660 BRAZIL + 8 BARBARCALLY 543 wLyBmkikB2044 908-531-5952 PERU + 9 BARBARATION 132.42 iiw0Bg2PPBR 42k iw 513-596-8472 ALGERIA + 9 BARBARATION 21 2P6wNkN24NgP 912-655-1882 PERU + 10 BARBAREING 21 wLm0 iPyNkmNPmwmB 993-592-8926 BRAZIL + 7 BARBARANTI 0 NRPB2B P 0BBw20yRN 746-634-7967 PERU + 7 BARBARANTI 0 L00wi2iB2R Lw LP2 254-684-5865 EGYPT + 10 BARBAREING 0 26PP6i0y20yiP4PLmNyP 897-842-8196 PERU + 8 BARBARCALLY 0 wPw2BP6RRkPk PBL42 517-371-7996 PERU + 6 BARBARESE 0 Big igy RyLR 702-728-7110 EGYPT + 8 BARBARCALLY 0 0LiiPPwggy 415-587-9162 BRAZIL + 10 BARBAREING 0 yLk444 LB Rk 222BL 910-889-6085 EGYPT + 7 BARBARANTI 0 i6By BL wmk R 228-534-4528 PERU + 9 BARBARATION 0 wBNy20gmNiLP kymBR0 121-143-7689 PERU + 7 BARBARANTI 0 46R4Rg PBBw 207-246-2175 EGYPT + 7 BARBARANTI 0 PgN2y 422Lw gP 714-875-8566 FRANCE + 9 BARBARATION 0 L06gN 6BBBLikkwg2mw2 410-137-9683 BRAZIL + 8 BARBARCALLY 0 N6yNyL6RmBgLkwRRw4 218-218-7646 PERU + 8 BARBARCALLY 0 Lw2kykmRN2kgiR2P6w0R 186-295-3252 PERU + 6 BARBARESE 0 w06kwPywyLw44y 816-833-4268 PERU \ No newline at end of file diff --git a/e2e_test/ch-benchmark/q11.slt.part b/e2e_test/ch-benchmark/q11.slt.part new file mode 100644 index 0000000000000..9c055409a0778 --- /dev/null +++ b/e2e_test/ch-benchmark/q11.slt.part @@ -0,0 +1,16 @@ +query II rowsort +select st_i_id, sum(st_order_cnt) as ordercount +from stock, supplier, nation +where (st_w_id * st_i_id) % 10000 = s_suppkey + and s_nationkey = n_nationkey + and n_name = 'GERMANY' +group by st_i_id +having sum(st_order_cnt) > + (select sum(st_order_cnt) * .005 + from stock, supplier, nation + where (st_w_id * st_i_id) % 10000 = s_suppkey + and s_nationkey = n_nationkey + and n_name = 'GERMANY') +order by ordercount desc; +---- +11 42 diff --git a/e2e_test/ch-benchmark/q12.slt.part b/e2e_test/ch-benchmark/q12.slt.part new file mode 100644 index 0000000000000..aff61b3249568 --- /dev/null +++ b/e2e_test/ch-benchmark/q12.slt.part @@ -0,0 +1,21 @@ +query III rowsort +select o_ol_cnt, + sum(case when o_carrier_id = 1 or o_carrier_id = 2 then 1 else 0 end) as high_line_count, + sum(case when o_carrier_id <> 1 and o_carrier_id <> 2 then 1 else 0 end) as low_line_count +from orders, orderline +where ol_w_id = o_w_id + and ol_d_id = o_d_id + and ol_o_id = o_id + and o_entry_d <= ol_delivery_d + and ol_delivery_d < '2020-01-01 00:00:00.000000' +group by o_ol_cnt +order by o_ol_cnt; +---- + 6 20 50 + 7 30 40 + 8 20 66 + 9 46 47 + 10 0 48 + 11 0 49 + 12 11 17 + 13 6 0 diff --git a/e2e_test/ch-benchmark/q13.slt.part b/e2e_test/ch-benchmark/q13.slt.part index 3a82e34ef4c19..01f958cc8b7c5 100644 --- a/e2e_test/ch-benchmark/q13.slt.part +++ b/e2e_test/ch-benchmark/q13.slt.part @@ -1,7 +1,7 @@ query II rowsort select c_count, count(*) as custdist from (select c_id, count(o_id) - from tpcc_customer left outer join tpcc_orders on ( + from customer left outer join orders on ( c_w_id = o_w_id and c_d_id = o_d_id and c_id = o_c_id @@ -10,7 +10,8 @@ from (select c_id, count(o_id) group by c_count order by custdist desc, c_count desc; ---- -2 4 -1 4 -3 1 -0 1 + 2 4 + 0 4 + 7 1 + 3 1 + 1 1 diff --git a/e2e_test/ch-benchmark/q15.slt.part b/e2e_test/ch-benchmark/q15.slt.part new file mode 100644 index 0000000000000..e1e7c8c7f75cc --- /dev/null +++ b/e2e_test/ch-benchmark/q15.slt.part @@ -0,0 +1,15 @@ +query ITTTR rowsort +with revenue (supplier_no, total_revenue) as ( + select (st_w_id * st_i_id) % 10000 as supplier_no, + sum(ol_amount) as total_revenue + from orderline, stock + where ol_i_id = st_i_id and ol_supply_w_id = st_w_id + and ol_delivery_d >= '2007-01-02 00:00:00.000000' + group by (st_w_id * st_i_id) % 10000) +select s_suppkey, s_name, s_address, s_phone, total_revenue +from supplier, revenue +where s_suppkey = supplier_no + and total_revenue = (select max(total_revenue) from revenue) +order by s_suppkey; +---- +5 Supplier#000000005 Gcdm2rJRzl5qlTVzc 21-151-690-3663 14739 diff --git a/e2e_test/ch-benchmark/q16.slt.part b/e2e_test/ch-benchmark/q16.slt.part index 8e8f978af7cf0..135e6566a3dca 100644 --- a/e2e_test/ch-benchmark/q16.slt.part +++ b/e2e_test/ch-benchmark/q16.slt.part @@ -3,7 +3,7 @@ select i_name, substr(i_data, 1, 3) as brand, i_price, count(distinct ((st_w_id * st_i_id) % 10000)) as supplier_cnt -from tpcc_stock, tpcc_item +from stock, item where i_id = st_i_id and i_data not like 'zz%' and ((st_w_id * st_i_id) % 10000 not in @@ -13,104 +13,1500 @@ where i_id = st_i_id group by i_name, substr(i_data, 1, 3), i_price order by supplier_cnt desc; ---- - 00R4wRkR0LL04R4P060L6B06 006 16.81 1 - 00R R24yPmkkgL6L 6m4 L i 26.24 1 - 06wy wk22RNywgg0R 4gP 83.83 1 - 0B4R wgm Rw0 BmNy4 Lyy 46.94 1 - 0BNL202wNmg4BPyi 0im 56.59 1 - 0gNLB6220yLLwRkB46LNRmg B4g 84.03 1 - 0kP6k0igRPmgkm iBB 49.62 1 - 0kRw2kPLRky42P2kLLiw 0Nm 84.56 1 - 0Nk0y46NgyLgRLNNk6 gwi 11.59 1 - 0NP2 ww6BR4mmiwP46P4L ik2 19.61 1 - 0Nw24w4L4RNwmg02yNB42LLL P6i 80.83 1 - 2L0w22wy k 2626BB m6N 42.18 1 - 2LmP2Rwiki0gRw g 4 73.27 1 - 2Nkkg46B0B0i 4N L BRi 16.17 1 - 2P4 Nykmi N6RkgR0 Bw4 67.21 1 - 2PmRPPLm yLi6wPm i kNy 76.47 1 - 2RmPRyi2my0mNm yNP 30.4 1 - 2y244Pg w6LiRPPBg 6kg 64 70.27 1 - 4Bwkyyky220NPmR2Bw0 P2y 53.61 1 - 4iiNR mPyi 4 k0 70.29 1 - 4iLi20wi4y2iNwmBN4NiL 6wR 91.18 1 - 4kkP6LNNPk0i22L2gmi2B N4L 8.95 1 - 4y 664262R2LLPw606 NP4 88.2 1 - 4yiBgmyw 6NRP4i2 406P LBP 69.67 1 - 4ym RgPkP0Lmi24N4LBiLP4 22 97.57 1 - 6Ni4P2wgy40wmy6g Lm4yw 2k0 77.25 1 - B44imm6Bi4Rw NN 2OR 22.67 1 - Bg6Lw4 NLmi imPmkwwyP6PB NBN 90.06 1 - BkL66L20kg iBB0LN i26 22.31 1 - BNN0RwL2N6 iikRg6Py2B wR4 59.31 1 - BNR06R6wkNy64By0i 4 kBB 82.1 1 - BNyNPR62my6P2 4LmBm Nky 98.67 1 - BwiLy2BwL4gBgiNL0y0 yy k4P 98.65 1 - g2k2mPLLNykLwmiLwk Nki 89.45 1 - g66NiNR44mRi0LiRgLi Bw4 13.31 1 - g6Ry4L26LiLLyLmmNm2yBm L4m 26.86 1 - gB6kg4NP202iiRgw62Rg0m66 iik 16.79 1 - gg2N66iw m66N6R0 60N 44.53 1 - ggLi0k myPLwPLgPR N6N 63.16 1 - giNkRNPyi646yRk 240 96.74 1 - giyPmgPRLmy6NLwywL 6 N 68.65 1 - gkw2BgP Nmy LNR 0gy 46.43 1 - gm0B0gLg gygmi PwBNLy6 kiP 97.28 1 - gN0my4m6wyRm2R LPP 65.61 1 - gP yk46LgByP2wiw N y2 78.61 1 - gwLNwmP0BkNg2wLL4ky0 Rm4 54.7 1 - i64NiBBBN0yNwN4NBi gR4 44.48 1 - i6gwLLyi02PLR PB0y0 4y0 72.47 1 - igm wLm0wmw6B2BwPi26k4i RRg 66.89 1 - iNLPyyyBmyBB64 yNNmi ii 87.18 1 - iR0LgPyBLmBygBLyP0i 6m0 32.28 1 - iR66NBPywRRB0LL L m 38.95 1 - iRL 02 BRi NkB kLmBy4yk kwy 50.68 1 - kmRyygPB0R LPRB6NLLgPw 0iy 63.15 1 - kP6w46LL0mwiLy Ri 96.23 1 - Li2RBiyBR 6RBk2wm0 26L 94.77 1 - LiNN2k0NyBP66gLmy RPw 70.12 1 - LLy02gLB0m6PiN2B0BLm40P m4P 84.14 1 - Lmk66N4Pm N LB6N6LL imi 66.25 1 - LN4L4R2PN0wyBkBy 2k4 69.23 1 - LNmwmiP 4y0B0kRw6 L02 8.91 1 - LyBw2yy2yNLwNww i R 56.7 1 - m4NBwRkP26wBy0PBB 2 wBi 53.89 1 - mgR2w64ByP0ww 6PgiNPP 0R 7.45 1 - mgRyy LkB04 g64B6 R P 6.99 1 - mLyRgBP246Lw 2Ng L Ngy 15.73 1 - mRyPN R0gL0gg2PN4iPm0B 04B 25.27 1 - N2m2mkRi00ik06gwmggw L w 98.28 1 - N6ikLkkgi2 gwL mBk 35.78 1 - Ngm 4 w0i0P4 P mii 94.81 1 - NmkkBNBm6ygRm20B R wNm 86.26 1 - Nw42L0y6w4L6N wg0 Li0 3.97 1 - Nw62LNPBBkPB40LNm0ky NP6 36.07 1 - NywmykRkL2NgNBkL Lgk 30.84 1 - P0y4wgk4y4BLPPBkim Nw 94.66 1 - PBBkyLwL4RLNNkLw2k g4L 28.67 1 - PgRPyLRRR0kP66L64 iPy 96.14 1 - Pmm0R yyPy6mR4ky2 g02 47.04 1 - PPgg0mLPLiw2 iiP PiL wBi 62.99 1 - PPky 6Bgk0 R0LNLLR204L iPy 27.36 1 - PR464g0k0iL kPgN0k6g0 g0 k2y 99.77 1 - Py2R20P6i ik0yw R20 39.7 1 - R 4 Bi4y B2mN42R4PgL LBw 45.07 1 - R4iLmygg64Lgwi 6 P 90.22 1 - Rk0y2 k0ww4wPLw4y gm6 83.81 1 - Rmgk402k6PRNBLLy 4L0R P0 92.56 1 - Rmwy6NB4y2mkP iP 3.22 1 - RRg4y006w0g00w24Nw0 yim 17.56 1 - RwyP6 wwNP y6mP Bg Pk0 11.97 1 - Ry2 PPPi224444B4mi04NgR2 iyP 28.6 1 - Ry6RkRiRNy6mPy0 wBg 26.46 1 - Rym4BkLg00kPg4NNBm By6 10.88 1 - w24kmP RNBLmw6Bmki 0RN 95.49 1 - w2PBiBLmk2yyykN LRi 85.37 1 - w4424y2ywPw2BBP642iPw Bg0 78.43 1 - w6BkPi0B iPR6g2m4mi iRg 27.66 1 - wPyByR N N2wP64N wN6 9.39 1 - y6i g 4N mPgLNi2L66iiy L00 45.46 1 - yk6Rw6P mm2kLk62 LRg 15.88 1 - ykk42LBLm6i02gkwyR gwB 37.6 1 - \ No newline at end of file + 01uXuK6OZMODiUhZYqZ HpH 75.52 1 + 07aYp3TpS3pCsDM BIc 75.23 1 + 07jjDag1YcdxlZP154kSU Pyx 26.65 1 + 0CE4MnYQ9nyebKYTXZ6la Zpk 58.31 1 + 0cwtAiCvQwY1y2pLMTtUq e37 1.16 1 + 0DD7nJVZPX9K1QI1 Zaf 11.39 1 + 0egbqpQyvZL63n 8Nz 6.44 1 + 0embTdtNyiEuE1JYT4AI 5Gm 63.15 1 + 0F55aN1ZZYELTEU1nGr HGj 73.52 1 + 0FljyS8XJP6gHLwEgJmQY2c IxG 6.45 1 + 0G1hQ1ExajUPzQ2yOmHz Q3s 37.32 1 + 0I5ILKiFX2LLbAaISFr N8r 50.47 1 + 0inz3j2V9HITtly FGP 87.03 1 + 0j0eT9e3wJkll6xGB6PJ Qnn 50.06 1 + 0J136pDbmZCEMPUwEk dVO 13.33 1 + 0jPzybyTKB4l5W jPH 58.44 1 + 0nFShQXFGwt2VQd5 nWM 85.79 1 + 0PrMPMp4rmvXTMopEG2WKgpo sY0 93.29 1 + 0RBB9b7MYaFSSY3DODqP7 cy5 4.27 1 + 0SD3M25OEUzX5KXIzyV J1k 75.5 1 + 0TmKzqDa4k4jLjEQgm8VD24 Bg2 58.62 1 + 0uunc2fQ8ungFUMGXSI2XiRr MoQ 45.54 1 + 0vxugnQUNvBdJzgcDrz2e 1bW 1.12 1 + 0wLfOnrI3lFydeP 1lZ 74.06 1 + 0XLLV6spwwlnM3WQ 1Fv 80.76 1 + 0xrwC40rHAQIpx6jplVLR ImN 54.81 1 + 0XuK2i7G2ygK5P vfz 68.18 1 + 0yutzesK1nDc0QJRAeof R3J 31.47 1 + 0z7olVfNXWNXfhG8OEGWt 5sQ 17.04 1 + 0ZXLkFqG9uJ2ZqDBVm4W Iyl 2.39 1 + 0ZYulphBWFzzVhbopWB5sRcO sMU 72.51 1 + 12UAZ0wdnLEVVQpsh0BT7 vFu 4.34 1 + 15K6z7GHDqQh1Z8JUND7JS5 dgH 91.4 1 + 18JkL67LfysPmMAyGy4AQUj ln3 36.98 1 + 19QoIfAcs7MvHq4HWLczL ISR 9.93 1 + 1d01IShXdDLXxsq3 7rw 43.41 1 + 1etc5ANYFJyJmKAqQ9ZLc NBI 47.76 1 + 1FchvojM13bOJ5dKsMpvqCE 3P5 12.47 1 + 1gc8yvClZUNzUVOtXIUxO 8DO 17.67 1 + 1gJrHpBOwxH7oDo1JSqPy eJl 56.75 1 + 1HO2hmGtPbnx5eqKByP 8w1 92.52 1 + 1JQQvRXDuJQWlKiHbN 9t8 41.31 1 + 1KmIXNGL5R9gMJKNYopWl3 wFb 3.92 1 + 1MyjiSoO6LGEtOaJmppw W4a 43.85 1 + 1nCV8NcKQjn0BUMqh mJQ 42.49 1 + 1QzoYSwvyyU6o2SuNll69Be YBi 58.23 1 + 1R84QZh2NZ8GHnqOUwXR dFa 37.55 1 + 1rwBIhPfllzfkqORzc mvD 84.3 1 + 1SrAieqkGPKYvaNZI03amiou 3IW 71.77 1 + 1T07PxRuW822PlxyRONOm9 Ntm 38.18 1 + 1udkwSOGXIcIO4odN4mpO JEf 78.63 1 + 1UvmDizBLbYocU5Nx2kBh HWR 70.6 1 + 1wNlTDhBxDy9pg1t mXJ 62.51 1 + 1x4h6cd4oFGerRvftfWiv Wb0 58.09 1 + 1XIAa19ulNozTHw 34m 65.16 1 + 1z7hqLI60armfJR HHp 12.66 1 + 27yhzsXIpV506A2 qB2 44.83 1 + 28aH3x9EAYPG1RvrHs Nob 89.76 1 + 2bVqfwvKbtvpvS9lvokZOaQP 8N4 6.81 1 + 2CmGCNYlnla9x0hYE6nkz17T Ge0 54.05 1 + 2dOuOvMzNa794mfXfab iqe 95.62 1 + 2DVIShlnyj6QdJE8tSC c9o 33.96 1 + 2eKq9Za122IRHLkrnh5I42X f1Z 13.4 1 + 2g52LR3zMP2i1mPaZ3g ynH 52.52 1 + 2GLER9h3QY2bhbdA6CK36LyJ fm1 10.46 1 + 2GXn7LpECQQDGi4v1wEr 2VP 2.19 1 + 2HabGOdRtH4pxHO nyB 13.46 1 + 2HV4ClRg4DjvVW7gk1Md 9EN 15.52 1 + 2IusJjiygZinz0huhs1Wyx soe 72.83 1 + 2KYf1Lv3DA4gh3w8b rZs 60.44 1 + 2NljUxzNts1xtOMFaLCk8c4 1LW 30.03 1 + 2oP4TTilONMlepaeUTX2H 0JA 59.54 1 + 2p60ZsDO9Gfy9PYU sys 61.17 1 + 2qCbVcpHLzUPfAewtNVc0dD5 Ifc 72.59 1 + 2qkTLJ62rHd63evB69up Bvx 24.31 1 + 2qNHseYOehC5FV gf2 82.73 1 + 2RPE559VzWN0G1VAOCYmKO K4i 71.21 1 + 2s0lR0P7tbwYI7evJ L55 33.96 1 + 2TnUNcFERiiCNqn3F3ccxa SAT 83.84 1 + 2V1RlsmHYia0hT mkR 22.79 1 + 2vpHzFDpCgoPWSVzT40pPG5 vnp 18.12 1 + 2VSBF0bCzxNhDGL 3kW 75.25 1 + 2VZmD79KsjictWK74GGwjeS 9db 45.13 1 + 2wzqCCkL8gUkRWc1k NdN 77.59 1 + 2Z8orBZAbJSnamlR HhZ 54.97 1 + 300oDwvuSmWpAWJ5hbHk NWY 73.41 1 + 35mvTwvJJ7zZStHT dBh 6.5 1 + 38sP5pVGfceozKc hrs 69.86 1 + 39AvjAgtuA6Sy8BcunZOv K1X 58.17 1 + 39hfOXhwUigq0UnB4 Bp1 90.02 1 + 3ABzYWHvv9FjVi pzD 68.04 1 + 3cQ1MsSTnSmjnfzHZo6IWE 9xw 40.28 1 + 3DcnWpHFzCuyMu IzB 7.98 1 + 3Eq5jXIcCsxR3Rc c4X 57.87 1 + 3eqa267X8jU6om5GHMiTI V6j 90.4 1 + 3gZgg2iLfUmYTBR G01 39.97 1 + 3jmHp42gq0Xbck34hC pQ1 62.22 1 + 3k02bgHbYFY1ZVA79clTWj3r wum 62.76 1 + 3K2NkH9n6YThEGawTN7ij5 6P9 39.97 1 + 3KOpSYDpYfEtLhGRgYVix9V XY3 77.61 1 + 3kQmYMpABeL9Fla KMq 61.47 1 + 3myNTLT01RQpDKcrE aMS 75.33 1 + 3nvXvTE6JQ5z80cak3oRX Y4V 93.68 1 + 3OJB5qJW1cgqO3JAE JRV 78.88 1 + 3qEXIlYHLfzDPuCns kgu 56.13 1 + 3R7WuTbpvZUb5aH8onY qZP 47.75 1 + 3rl6Rp9M1cu3vIbKy3VZPAR AwT 87.74 1 + 3rnVwM0CkS89krQWfywnndl C1C 77.26 1 + 3ThKi5S6Cc5ifN 75P 15.07 1 + 3tiCmI8H2Azy3QBzrXpm bu4 75.63 1 + 3tU6P6Uw1hkfWnK1yMedSNq sYS 90.49 1 + 3U8AzCOwfjgS4RHumu8do VKf 10.93 1 + 3Uk21kVmjqfgu1Upyo6UV dLY 86.1 1 + 3V1uT4HmP7dGjefiFHL6g y2u 28.43 1 + 3Vc8cb5rWRunDjMRVuO DDw 43.15 1 + 3YUGkPko4spNRqs5vU7o5 yxp 61.46 1 + 48e7v4yeun7nkKCn CG8 30.81 1 + 49NmzJTnSOdfcer uiD 91.65 1 + 4ap5L86I9N4o6CCYvDsk SjT 43.66 1 + 4AZnQvvsDCupgTHYlgHJMi5J Y9a 36.76 1 + 4boPmV9IzZ27nNV rhn 9.36 1 + 4eztr0l7XpAJDtRlHq RcR 70.69 1 + 4GswP9lVt14oUlP2upG2q 0Lv 45.11 1 + 4Ha2KoPaQqAFuoPY fd0 38.81 1 + 4Hxpz7iX50rxW886VhHXigw fRd 50.71 1 + 4I376OEcNXQc7lam XUZ 80.47 1 + 4ITYwi7mC1gSZvxweyBEOBan ZVH 84.87 1 + 4JJMcZjZtUSGJ7oR4dE pQH 87.1 1 + 4KTGz1GH2OLasUqOk ygs 84.61 1 + 4Ll23jur0FD4nAjh 2Yz 39.4 1 + 4mgFAjtvriX1JNk7rnJ98rn1 PCX 60.89 1 + 4MNJeZprl08AIGHAJO7HAm Egl 42.25 1 + 4PXGohN3FzrI85 vd7 3.25 1 + 4Qz9D4O5tAeVFmMB0GL2Y BOf 60.12 1 + 4TlC0HDgZEAGsuZ8fq oVw 99.79 1 + 4UwppJQdwghEoZJdakYDO 81C 46.43 1 + 4WBmUyeTwKCBUMFa8Ku3Ini Omd 76.11 1 + 4xLfR2LtElmCG18gGG 6lK 87.54 1 + 4YoLClWCZdrTBAaxp XtP 72.44 1 + 536wlJlRD6XdEI AST 24.59 1 + 566cawOsOsW4jKu jTj 64.62 1 + 57jRLEvhC70vpY9TT eKR 2.03 1 + 5d5GxAD5Xz02SQM8qi 3mG 80.04 1 + 5DDF4nWRzaRVoP61rt5 8OS 97.13 1 + 5efu0qAiUFVuxxSwptHl Tcn 48.74 1 + 5Fk6SvdQ5aZlqAs1z5gEv y27 99.59 1 + 5fxjgD4VobVCFVyvWKw3flox uvK 62.2 1 + 5IsIzgweXipH5z TZ9 50.19 1 + 5JIxvfplUTutABiR6iqquxT3 UFj 94.42 1 + 5K0SqxD8WVEvXII KRT 5.7 1 + 5OCb7j0IfRYaPjHbex9wC 4Pi 37.76 1 + 5OidY1SPIPIXarfL492190w EWD 24.19 1 + 5p2b2Ifwi1ZuIlmWWsP 9Cn 99.21 1 + 5Thm5C86Ujyk1xaYBiH1Z zol 53.87 1 + 5W7Cc7utqPUduQH e9w 69.65 1 + 5wu6VwjYzU2XBlGQ 47A 93.35 1 + 5WXZVf8liaJScjU2Rvha sUx 9.26 1 + 5XLzOBNP8xhci6ABduY5WJK6 eqW 35.63 1 + 5xZF9H7wXuwQah6ozG8 Aaf 52.68 1 + 5y2usGdjbBekjHaNR5Ln vs5 30.79 1 + 5ZHGysQtIiH9JimlltPWziA9 sUi 45.59 1 + 5zjAKxhqJBohOEytNInJhkA Mdj 43.14 1 + 61mrIYj5GVFU69Hg9OatBF SFn 55.12 1 + 67xpLHTxQwpOlYZQwRri Jhf 84.88 1 + 6AaE9FzSJ4aDIP BQv 91.77 1 + 6bHlYLAG8QHj4XvCDXLrIwXc 2uA 15.09 1 + 6Cid5cHWE0Jhvbf3J 3er 27.68 1 + 6cZx72GFdt25mVc7AjLWjfT bdl 59.29 1 + 6D7RVkgWk2bnmhsrBn5SgAgR FrX 14.55 1 + 6dQCixVfPK0ZQ7HU 1SI 50.63 1 + 6e5PB50Um2nsON3Cx 4ID 65.56 1 + 6ESn3imNefey3XCV8HBp0sn bzE 22.18 1 + 6EVCwF10JoQEpwa QS2 80.64 1 + 6ex3KLAokE11KoXstCy avV 72.98 1 + 6Fxn98E4iF3jfFC9fdcAaV9B j7b 5.04 1 + 6gSSrGFDR4aB98DjB 7f9 60.05 1 + 6H3pGnNeCVsHlaqvePHdnB cDb 61.2 1 + 6hejCEJaJ1FLkHacbfdN0BZ seZ 37.17 1 + 6Iw1USG8emyFZmjUc GBv 47.98 1 + 6O42vF13NWukYGum9eNzcv 7qv 39.27 1 + 6PgMxngZPNRnj23GWJUef8 YvN 78.56 1 + 6pLDbjXLY57HlD kjD 39.26 1 + 6PX4rFXrE9DHKZNQoRrzz YEG 36.12 1 + 6q3dxALZj0gBIt CFw 14.25 1 + 6qjUjtqITDLjOJGJL6vO 6d3 62.29 1 + 6v2mHTEGGqR8sqAP1qUWlz Zn8 87.87 1 + 6WFuGuN5nT5MSeSPVptx yUh 63.22 1 + 6y1RUqB9hAq13DWU 4E1 65.47 1 + 7038A20mvPMdL0Tdg6YBo gQX 94.13 1 + 714mrZnEovj5X9 xoc 91.37 1 + 74FpqbrVGbroXFzevznO7 nxw 68.81 1 + 77UlRl9uiYm7oe1gDqAleq Qrf 7.5 1 + 7a15QhItetfTZMw lrE 12.29 1 + 7aArq6vlvvcjKzx0D wU8 17.21 1 + 7C8Ct1uo16Ytg4g082q3 o74 50.67 1 + 7cKdnL3mg1NFEIwNZ3cm Dix 15.77 1 + 7dpSRUiiDs11nFzF gn7 60.76 1 + 7DYyIBiqXj0jWYr DnK 29.41 1 + 7fbmxdUnxIol0avVYxR Mn5 84.85 1 + 7GGctlwyuIIOtF6rknjJipd KDT 98.4 1 + 7GUxd5Db5DvYnY 1yo 33.1 1 + 7HOIKWGSTIo6oSZDsUJ1cbO VgP 79.33 1 + 7i3AtnvkRInMqRLgS6c1lUn lcf 76.58 1 + 7Ianh5mGmeAOTw14r ori 45 1 + 7iGc7POUuDtG3DXogP3Dx Csh 32.61 1 + 7M6gx4o1mE14IrN0GOAitrdj KT7 64.27 1 + 7NP93V2hko9HdotpNFj wjN 19.59 1 + 7PxurGSq8yDvt7c wor 68.24 1 + 7q1VcxgtxOax0uihVP4 eE6 33.83 1 + 7ry0140hywcAKaoZg Ern 40.62 1 + 7tUuzFlUUdxJLk oD3 88.57 1 + 7tYij9P4iJTc8bQbMNmAZt F0J 8.94 1 + 7Vi8cLVDUeypkptmG9en gLV 80.17 1 + 7VZxzGYTsR3UYuAax ZAI 68.95 1 + 7wjWYq8oGBxwYI fJm 67.6 1 + 7xAnW0EwRHp4GR DdL 43.16 1 + 7y9qcDzViNZNLuG6f23BYi CN4 3.22 1 + 7z0MWQSy1GZhRNlgBho iwP 8.17 1 + 7Z1DN0ASYM3S40VXQ8dHSjJh Bwd 7.22 1 + 83bOSm7TfAD9OAv7Fw CdU 27.48 1 + 87uzzaHkdMSx6js1m0fY Odb 89.63 1 + 87zWFcjqF35LYcVt7A8 2LO 30.38 1 + 89NEZhJ3UnjPcrATwB1tZl PaX 34.34 1 + 89PLWOTGJBZ8dm xda 23.5 1 + 8c6XsicYBPr7fpd9r6pf2pe XSO 86.43 1 + 8eb2Pv2tbwp5ZBEXgDL9m wxc 23.91 1 + 8GA7wxUD6GFT48LLT axn 35.7 1 + 8gl6ruVJi4Sqsqtkg6SE dZ6 11.11 1 + 8gxCwhG3ZI5uS4CUP6uKA vVi 63.09 1 + 8Jwx1gKigArR3EEgZJ9XmHFX Bp0 27.2 1 + 8kp3b7GuUtUKIXBSBoc1PVV 6ne 77.25 1 + 8lwJQ2YhxZOJUP5HSh2TU KDn 9.42 1 + 8N6cAtUlBbvAW0Iz1LgkuN zmS 29.56 1 + 8oIENyH69O9ija hkk 44.74 1 + 8OkwaYFfoISRWXkcQSq gIS 85.76 1 + 8OvqF2FrBbTL7mNeF2 ALH 18.93 1 + 8Sx0gcbAFZ48vnXANPoQ7 OcF 74.8 1 + 8T3lJaTvZHY2vA A1W 2.48 1 + 8WGccvW3OYjz96jE deE 88.34 1 + 8wJRn5bkPT3GO08dYNI5C MdR 25.14 1 + 8Wo8hsuoth4MVjq6JT1bopKV eAJ 92.28 1 + 8WPZL576afA7S4nfw51qs3MF zyL 26.86 1 + 8ZlJH5WwFTs9ZZIIjwVI qIa 32.59 1 + 90QBpHSk4UAB49uUn McN 66.62 1 + 914oNpnwBAXXOFocdb0 f4p 67.25 1 + 946rW7iiQldO7gjU 6du 46.97 1 + 95xkmPy8aan6FGGfFhcsYj1B PDH 4.31 1 + 96pqRpUoKRYSwO QY9 48.9 1 + 9765InZBeEvVYk Qbt 57.7 1 + 9awoVwqe8FEcgJQfFJ FkY 71.27 1 + 9B7GBbwhGmR4d5qudx CHi 92.64 1 + 9bNV4WMYAum1TwqYCT9XuZ p8q 27.21 1 + 9cPYYTiXEyUgKUsu6uAYNBB mdX 57.77 1 + 9e0hEfx0B96dXvrJabce 9Pl 40.88 1 + 9G614pk4d5F4asNDl YCU 3.34 1 + 9gGgeP1EpEVELrmWrkYJlPz VIh 86.51 1 + 9HQKEdIKzGUQsJSCsaHWwh Jyw 70.6 1 + 9IrUrS20qjpQeoQL Ago 18.29 1 + 9JjqU3EskbDHNt AVT 68.79 1 + 9KZXjE0hHBjjWgNsz4l32 Wgt 64.24 1 + 9lfMdCdBGwqbEtnU jwq 81.56 1 + 9ma1cYNnsSjd010d8n nwS 67.13 1 + 9mEPJpH5dGBkggzfOtzdyO Qwk 67.11 1 + 9Mlr4wWav0CuaUHxX0dT8S5 zb8 27.14 1 + 9MV8yNk6CYTlmgbdQrsmLb WcO 53.92 1 + 9MyEcJV9oYGtqpoeizPOfD5 YNx 54.35 1 + 9om9GszdJdFiVt5 wSB 82.33 1 + 9q6R7WHCEtrSGpDqESIYHHo VZu 42.96 1 + 9uPt07zv4k0muOmiJd 28u 85.52 1 + 9wVIpEIFau7wWvhG1EyyC b6Y 69.74 1 + 9X1eY230dGLgvtoSxZIzzw xIV 12.08 1 + a0I1a1RFf4zLH1D YAM 48.26 1 + A17AHiDCgIwKL1xMg X8B 71.39 1 + A1wk9yteGWCZQBr3C S7t 22.65 1 + a1YFKlWCHRPoz9IL6Luloa Eme 4.62 1 + A3dJP7RwfLbLDc9C6E zFT 11.66 1 + a7LCN189wUUjodznR3cGxSg 1Fu 74.79 1 + a83PNz8oZNDVGfLV9rKT0Tsh sFw 57.93 1 + a8ieSTL7yDEet1 fqt 95.35 1 + A8sSOqsEgmavpqduc8Xalg 5Os 73.48 1 + A8ZECWjx3AM21K6hc 806 75.36 1 + aa5hqRRvupUCDu9NCBsP6zZ vB9 39.52 1 + AAaEXNeuplOBwpu56e 1fr 48.32 1 + aaiFxWjUtXKRBumYmSqlgYRb Vy0 68.36 1 + aakp3Rb901rsOLDuWlm GAE 45.86 1 + ABrVvjo7Ez5J0B93Lrm B02 57.63 1 + AbRxrcWgjKMt9bog gmz 20.96 1 + acdVTPFnqogRx9gikMWsB 8jH 55.89 1 + AcouBSuAPwcncQmAs62YJ40I Pe7 94.18 1 + aEBQJ8fKJtHEKnaVi ghc 89.09 1 + afyrl7dgzuV480wawSrZjz l8R 27.44 1 + ajqkL1CxrCwaYpU Bw5 61.41 1 + ammmvqZaFqTlmSzq4f8lYIU2 vkL 99.73 1 + ANJGTo3gd9sSWXuB8 b51 64.75 1 + aNodcnMUwPoH4OoUN6 eup 8.35 1 + aNQ9iQNqbBKfMXzTUebiM oLS 9.06 1 + Ao65nk6BN9RdSjIvq7K vaw 43.62 1 + AoHcBTANC2iHwI8Q2JQe wRI 74.05 1 + aoU0VA3a8te7m3n3GPZYAy jHb 41.24 1 + Ap9fxOb4BgatnhrOYd Jhn 85.44 1 + AprMxezhKQkiI90 76f 95.36 1 + Aqd3WDzYIKtvZ0 fRv 78.31 1 + AQou1VPfElDotJ1iO0fMBe Faw 94.58 1 + AsmUT5Ddf8pOhhShTD yse 48.1 1 + ASXqv2YwLuIrLDi JZY 13.66 1 + atEN6joI3hy6HjfHz0 rqd 73.18 1 + Au2WFtP6KvuHiJJqXMHL BdJ 55.44 1 + aUADZmMjgFUxAkrHFx4bfRWZ 2Cd 84.55 1 + aUceCKfUdwp9dv Aex 33.22 1 + AuIpQu5q7Y2xx0 ADu 93.97 1 + aujyOBelqlItTXnygq tZk 13.88 1 + av1XVN3DkkMXa5Sx2gF mXG 22.18 1 + AvoRviqVfUwbndMiqp0nrXDV Pq5 40.26 1 + aXDoaEFeEKvLQRrjUXxdJwkl 5hh 68.43 1 + AxkjceMzM0Ap1FW Oga 84.37 1 + aYHElUwXeTTN4OCtUdt2H0 CEf 13.25 1 + Az6rlX7ZwlOkEPaZM La9 48.48 1 + az7p1Ca7EXYyYqweozRXs hHh 71.25 1 + AzB4zjIpYKNQJ0ipKH5Rb2 avb 40.18 1 + AztNBsoJYVC2n3r88zLmm5m hmw 43.48 1 + b1EohMuu3RFu0ODf 7D0 60.11 1 + B5dTiQWK4iABJuDQ gYD 95.69 1 + B5jsXCoZFMg11Z7Q3lfT4 Ne0 80.94 1 + B5s1E8kVO5zlpNEg5Ola 3Y9 35.44 1 + B6ms9OTDMi3eRAl9f HOF 55.19 1 + b7YSy12TSvJ4qmC8q N2k 56.22 1 + b8n7j410XuVh28CWuoMSeOt3 mhI 48.37 1 + BA578yFXXEEvny83VQk J20 40.41 1 + bAbnWECURh65qStcK5v DMr 22.28 1 + bB64XGJKBFr6Qo b3q 47.14 1 + bBeIYE38Pf8orcL7 mFn 42.48 1 + bbQcAYd5yUpIvoV4dWzI2fR wor 52.26 1 + BBtHQGFadWW7TY 4sv 97.53 1 + BCnDSGmdP1bUZcv1Yst4 jMM 80.25 1 + bcWm1WTcUUblbCsO QeD 68.85 1 + bDNRIv4PwbWiLcePGkt3J5i9 Xi5 86.21 1 + BdzUqfkACxCh3X7ZmXhpB vTD 52.71 1 + beA2y6z30s7oejMo pVy 50.15 1 + BEMkU6IJOUUmRL11VA JKE 39.62 1 + beUihKBvtpQwClc7P2L hoT 17.65 1 + BFrj8zsR50LywQJX6YRGuI0g ajl 31.7 1 + BG1QTcketZjbqnon 1O5 54.5 1 + BGJs6d3Aw8Kzoy Y2r 76.38 1 + bHcWXuIKQHeZVYckcbXU WkI 86.64 1 + bi2SGgPy13Wo8NDq shK 83.74 1 + bI7NQK0ayJdC3yVs naY 25.36 1 + BJLAO7KAYYdCgayAR Gba 7.82 1 + BjMgnMf4ju3cNJCeJorx D3i 40.96 1 + bkNT9eFwou8H5Ibrp0OTQIEK oUb 1.95 1 + BLxHyPe5wEuBL8e 2Tv 71.12 1 + bm1J81ixcngRDKP lY8 76.78 1 + bmm0lD9EwbCu79JiYcOI4kD apd 44.79 1 + bmSINAUvvNcdpRYZhO7 fPd 58.55 1 + BnWHlIWyi7z5icgInv5y M7h 5.3 1 + Bo8Ofln8Jl7ZTjIv 6z9 98.75 1 + bPKwejTJTCVkvNFdp hOn 19.73 1 + BracujQqozBU4B02w7Q V1t 43.38 1 + BTeqjDrbpfedOB97sKvo 2Tf 50.11 1 + BuqCgwuEKSLEXJbl7DYRYb1 CGM 69.47 1 + BUVXXhD5ZzCR1WSeYwFWC lXj 20.79 1 + BXpSIKok1i8bc0PBnj qfy 84.98 1 + Bz47cqfPkoXb18trv X4z 68.65 1 + c3bY5UHCcUeeL3kP 0XL 44.89 1 + c4HHPES3FZpMSJA8XYUeCPq GGb 31.41 1 + C5VbStJKARPNGGF bGg 25.29 1 + c68sxu623O8YDChZb 3or 28.31 1 + c69Wxuv2337UfUHrWDpkW94s jgc 76.03 1 + c72RcUM6kquID2BKMlI IKD 29.04 1 + c7KB3B3mGVLPL52Qjp AJQ 30.2 1 + c8K63odATjtt15wQGJmOgcg zYo 76.82 1 + cai0tg9EbojcgUSntIJ vzi 58.26 1 + CBjTJV2FR9ssRFWFxg uWy 46.35 1 + CC9v9P1cgR8CMRIa kag 38.05 1 + CCdirLrXki1nXilEYs0 Q7W 21.2 1 + CCV6dlwGGoHIdKf bdV 9.23 1 + ccyBivg6Og74uT qQO 98.23 1 + CflHQWTmYsYAQsaX6by ETQ 94.66 1 + cFwoWbof5taOcG2vO4NjVT8 fQz 53.52 1 + cg3qrHbpImojf6nFb4 Y5k 80.83 1 + cGG3cq9x36uAwKS bL9 8.49 1 + cHEKcUfelRkA1x 2a2 87.56 1 + cHGbyopcwn1sOJ3C1JaI 7y4 32.28 1 + ChpXXVI7HTKrQyzhWVYo 54z 74.59 1 + CL6yDYFT0iZqye Rli 19.63 1 + cL8iBoVhGmje8H0uzL gRF 33.07 1 + ClfAiKgpzjXO3alYdzfk UQK 24.89 1 + cMA9992gTjrTg1Fk6nCvS jyM 23.1 1 + CncETr7GBhksF5BnNb8Z tal 45.04 1 + cnch8V5fWDlpXH5gbQ zij 96.72 1 + cNDs0qxsFtQmNQhSCaOAc drH 85.07 1 + colbQo9bGmba9WP9yk hwf 90.3 1 + CP5vTwPc32OeGLsl Yx7 37.9 1 + CR444XAMHXYXTTwLfQR fMZ 98.68 1 + CRAc9VAflcz2tFFIZ jke 96.43 1 + csiDTpZeRu6KzdVEUkO7 csT 41.4 1 + ct9kDgus7GwujDa9njCon2S gnF 8.04 1 + CtmKhoBRnKWRQoJh Ht9 19.52 1 + cUNUne059wJJBjNc rCn 13.41 1 + CUUpEQEwbFdyJLPEIjE PVw 69.44 1 + cvdVs87UJyWPqILO5K6e XHC 59 1 + Cw8yMBd6tgk8WlZc 5GY 28.8 1 + cy3bHMkkHU3Kw4hMefmsgGpZ xOx 23.54 1 + CYJgePy5xZp2aclCtxsNKwr bRN 61.92 1 + CzOQqWCoj6S5vfPc8dT VQb 85.14 1 + CZuzywAYPka3z1vwBznlBEU zJq 52.65 1 + CzxoxkRQwJ0TcU3 eIZ 24.74 1 + D0b2m9ci32rRDbsYAx2OVatq QMi 38.02 1 + D4E3tGkTmMFFURPzZWpDT bbd 43.95 1 + D4Eg193yy1u2ab2lbcCoZ8c jUd 77.03 1 + d63n3xCzy9nbQk2x XnE 6.43 1 + d6gBO8IeXWzefO wbh 7.09 1 + D73MrWHMB6sVfCMsIDZ YTR 69.58 1 + D86Hpl2U2PU0aRjbB2zy 896 2.71 1 + daaJtWWiBE4jEnOFIRIQ6vh JTP 54.24 1 + DAbqyatqL6RNfOU sIo 94.58 1 + DBEY5elKomZVss08MmwTJtQ lGG 29.58 1 + dbS4HiRkxXxsqFArX Od1 76.76 1 + DCiyeiMTAKkeKdLWxk gHA 75.53 1 + DdbzS1Pc0I7Sx2I0bwiB6o hhR 63.43 1 + ddy7faiV2W5bru6bBjNBh L4Z 45.05 1 + DEp8fSabNYG6dUnBz9j ddO 11.36 1 + desg7VfLwOTSLE27HqYY Xbf 47.72 1 + df9o64ZVbq5kzsWEaaDT8tOi ga4 45.58 1 + DFdHiGsuSimk9tRbD7 Ln0 9.1 1 + dFEHtMz9mS14i0Yh dlO 54.97 1 + Dffzyrp2r3cmvEkyT7kH g25 92.56 1 + DGbeDwQDRUGKdSCrERPep dwn 55.19 1 + DGe1fA0tG4x0Y1F Z5E 88.76 1 + DGgSsFrTFpoi5C9DByr0WR XYo 99.99 1 + dhjVtCO2GdYxYE35LjnO aPk 90.09 1 + DiEiunaSiCY6NupQphS VnU 5.59 1 + diPp5Vu2b3FCDRiZwS uEA 27.95 1 + DITSpIICX8xjnobtqfX9 MQq 15.74 1 + diVJmsHNgwOtPEkd2 UHk 18.17 1 + DjAAAbpSCSkZkt1962A4 bKJ 48.24 1 + DjLfQWnpDD9lS9 y34 20.76 1 + dkVmWP2ZbXcQJCWbV6 wbp 23.65 1 + dkyoPwq0OS7NFX0noKC289 lrQ 38.2 1 + DL5sVnriKozl0Xd pWw 13.3 1 + dmajuncDjFIHNFrsZ aDQ 86.62 1 + DMHthiCcfdutxyaQfJt ANZ 49.55 1 + dmXu6Jusowkx2mT7p XDz 54.51 1 + DN88TyvqAlo0gNJ FtN 66.65 1 + DNB0kXgywLwfC3tUTgQ0l0 dsx 32.34 1 + DNQ5jyUkyI7Vpx74fSzyk6F 0Y1 82.3 1 + dOU9tRM7rifaGvJg tNW 18.46 1 + dP9WhVsOtSgHeSc7 qvo 92.04 1 + DPJwFp2rqttDmYfn 3FC 2.1 1 + DpYMKuCfq2CWeLvMC4sZ bCf 21.49 1 + dSWBiSQt1mKuS1Pm 99H 89.13 1 + DSxzmVDcRH9gsXRjO VSh 6.24 1 + DtCEabdrzm1tJabBp soz 14.77 1 + dTpL52LZU1bQhpHm1n4 pY0 28.45 1 + dUGDERmG8Vrnzj1CRQzcYU hfv 59.64 1 + dyA1aReE4XTAMsFrCyJjJUw6 DRW 16.45 1 + dyaFdJOlQj8RmqwU3kR9wd 9wb 8.62 1 + DZLflGTUx5rk2GFNQz 5zO 1.56 1 + dzp2Sgi6QZxxLejXi meb 31.94 1 + dZsyKuI6hJF9DzCd7ga6 g58 39.23 1 + e08I7ldipVbAzdci BNW 97.9 1 + e4rQdkzeNRUbIKyA WEu 51.64 1 + E4XCGvwjfaTDHjyiLvflhHOw s8g 78.11 1 + E6dSpkzC7rgMw83pQl1 P39 26.57 1 + e9g9AVNUrKNhRRtHfqBGtnLN nxy 52.17 1 + e9KDWFtPmHwMoCp56S 7Ps 50.04 1 + eAcHdsfyXS8nxYWk Mcc 58.16 1 + eaDCbG8rix0gzeKR5DQT DD4 53.44 1 + eADG98VOOEdQwx KME 6.41 1 + ecP3AI7w4yVvwk5 zLL 42.52 1 + eCZCT2xLDHkTlJ fWM 36.75 1 + ed8L2wdxiNc86DSg7xmOGM F92 89.53 1 + eFZxoCg67FkKJUSGuU usf 83.56 1 + EIqeCV1LyTse8DM wcq 88 1 + EiTDCyafUZfWDFXQMRW0bED 8DY 44.1 1 + ejvVQSuMtiZfWkcL O98 63.82 1 + ekmN97mJTm2eT1L WfH 44.15 1 + EnNdeREPTldPRIt LEu 21.64 1 + eNUw7B7Qryvi1fQSkQVB3vZ JRo 19.4 1 + Eoi9GiXCspUj8LDZ0Bg 1Gf 70.5 1 + eoNmcZZAlKPuIG5KFgn coA 26.27 1 + eOYP8MztMrQ3kE5BgBA Bdx 34.49 1 + epbF3M9VM4IlxGY Ci3 83.7 1 + EQhjeKCZKj9FbTLAZv1B96 G1z 22.08 1 + eqhYTsngwylVxKCCfTO4IKHX gqf 72.61 1 + ErAb56xD8pf555qNassG XhY 29.92 1 + essawDgvkdN8OytblGOOAHX E4i 97.32 1 + eSWaeN354IZCXYLf4WW3XK SlW 61.39 1 + ESwJbwgKXkb2te 0l7 89.19 1 + eTZtcP4XTBAGXP arC 14.12 1 + evhqR1IxBQPNjGud9 EK0 77.2 1 + EVvjOMXtGC0jwdFNybFQNx csl 1.91 1 + EW6wexpJd1gmIce sjk 31.22 1 + Ew7o4OjmhL2dtIAw1yutOk8D g3h 48.81 1 + eWdLHgE1dcx5pPJt 5mc 9.86 1 + EwhuPEN7OiwWF4q ete 66.44 1 + ewQ3ArVcOzw1ogm U8h 13.74 1 + Ex7bDUL8AqWUXTjIzYGA cWw 7.97 1 + EyMegzSdt28ykbxFeufsbVL gOw 91.06 1 + eZ3cV55kkZSlskmKrHekl7Z1 MYU 25.98 1 + Ezhqbc7At8Jn8q1RmZnJm A8Z 33.75 1 + f03TYXbdYkqz6kveKs9 Xm0 96.71 1 + f1mklqyXiMP7dOqMXJxWOwK6 YOM 50.68 1 + f1YL4SteqKeAgU1CefuURhF 9tr 96.93 1 + f2UsAY5ZP9UeJwk xC0 13.44 1 + f4uNzlSUBx2oac0oXtFj afS 28.64 1 + F6iHs5PMGRhH6v rHY 26.4 1 + F7cGzjaNlHu1zwpVtB OpE 42.18 1 + F8sItBZdDWaV7jeghje t0T 68.12 1 + FAWfHOhIan2Kg9fmzXrbklDF kLt 94.09 1 + fAZGgCJ3Fz2EaHd WnR 32.82 1 + fbEhfFT2WHwwhfUoxHH Dwr 38.48 1 + fBKFpYmbTSCurZwIBSC M3C 81.05 1 + FBkn79ijeNnQlJ FRT 70.11 1 + fC0pOjJCEzNkLUJC0jpm5jI xin 69.03 1 + fdcXsEKktWhgzsjYmyN4 F8m 10.36 1 + fEajBZOY3Q5OI6K99FW kBJ 81.3 1 + fG3613AQ0emkzdvX0oXZn CRi 51.44 1 + fgvY6TooB2ZTcJpEV5rTj4TL j2q 49.89 1 + fhYd8bR1CrmDrpenFY3 Meh 32.38 1 + FIAJUM8nnrHNa2va rRU 68.45 1 + fJYuteqa2fygw9prwdSV BgF 74.57 1 + fklohpdUdcUrvlmPdx SCY 56.22 1 + fKqrXY2iItUCflY1 zNW 68.18 1 + fL65j4xPQMMKeFtbBXvIgG1 mVv 97.19 1 + FlMrnPDhi3yIcQyPCH3gTPQ RTk 30.76 1 + FM9kzHbLGAqX4BD Kos 81.88 1 + FmbNGWMfiYt5m2j7 Tjz 70.77 1 + fmvj8i2csSbNAJP0 Urd 65.65 1 + fn76aJacxbh3RqZ060qkvxa rCK 29.59 1 + fNj0gPW9u1tKetV4XyO U5r 72.18 1 + FnRIWPBtJtx2CVGH2cC ETL 38.62 1 + FocqCYqnoXH10QFlFlyAM Xnq 19.52 1 + fOGulO7lbAJ3li30yYtadX aZU 49.56 1 + Fohz04gcGrCdqEzu4bB 5pw 41.61 1 + FOInEELTDAC0HdOXrR ull 90.82 1 + FOPiT4q7ipPm7q aot 68.26 1 + FPZexJxJ29Sk5TOWLb lnI 16.7 1 + FR52rnusSALHmeMhRguAeb 87L 37.18 1 + fTaRsKFYtUbCuDWp0YAMp ESE 94.78 1 + FtkTSk0SxuuEQpiuMzU7 06w 21.92 1 + fUk27ftwVIAveXDvilM ad5 27.65 1 + Fv8Cf0UWjc9m9t bDu 86.87 1 + fwe32cDW2S6x5g9tYmX1029v vUI 30.67 1 + fwQRaqSzyapTBNRY8h YTi 84.46 1 + fXqxhjhiqpioGKN XFC 99.44 1 + FyiDfYOp0Wo1dJ9 QDT 75.49 1 + fYq0b2ZyNUanvTtMrrhg 4Kt 13.15 1 + fZaI8AUqdtHfeyCq P4H 44.69 1 + G1IOV9K2NNS3xo9pGhUwyGy 56J 53.15 1 + g3C2HgCVqKzbG4Zn qiU 34.64 1 + g4j6Af6X7hAQlC8kV 1Z2 94.04 1 + g5zRx3qwv4QOu68c1AFQFuIc Mxq 99.61 1 + G6cNZtVI7yBJ6k2MceMxl v3d 73.98 1 + G6mlrxMRhCcG2r8 8OI 63.52 1 + g84ZHD9K0suew2BUFTiFz m0V 71.23 1 + gaCAaBGswfXtfCBfPlDE OF2 14.47 1 + gbRk5qYfwgDOh1F YZc 47.25 1 + gc8GbXA81WZw7F7W2vJ6 YZo 90.77 1 + GCrpuIkldMx9zavdwBqX QIL 86.79 1 + GEOh0768Ww2ngRsFgB26zxZf l7B 11.98 1 + gey8CaKBqdhvVYLp U49 74.12 1 + gFG1jBh5jgQNqDEdFVR FgT 90.09 1 + GG9JFc5ppg31GCk5pThel5qT PPl 78.39 1 + GH3DziNv1WyKzfZyay Ho0 9.96 1 + gHH6wWJcIFEki8lidH trc 16.63 1 + Ghu9qsGonYemNWb ZsK 6.11 1 + gHvTRO6CFuayHg6NqbiKpKQ l2e 37.66 1 + GicoS1qyqPsWMeth RbY 48.21 1 + GIGa8AU8vcUeFYHD2w4Am1 c6n 10.31 1 + gJH5WV0yMvzQsFfQNO2g LRb 5.21 1 + glJCE2ic334kqM14sckDx9Yn Nlb 20.95 1 + GM5o8awaZXgwZyUjkhk SBq 54.65 1 + gMBEZ5rY0IxiDn vfX 33.2 1 + gNW2s6x8BY3CnQpaMgDDJ g1R 57.29 1 + GNZ1hGReENDmqr yH9 85.63 1 + gPahrTSE52dMgk vss 89.98 1 + gPHLtWz0iYkJnTSGDVBR4 jgS 62.07 1 + GpK5sURU3bDLrEjU G0w 4.61 1 + gPmMspDGLd4G497wOW4ZWLf j5K 83.18 1 + gqUG8XAT4pfEUXP tfB 97.45 1 + Gr23IV925fKi7kGMEcHa0KbL nsc 54.87 1 + GRiJH8TNFBW4CMeswtLMiFXe OAf 93.35 1 + GS100o0r4lRObBILN 2KW 36.24 1 + gtwRabCr9rVx81MngNIgain h1P 61.94 1 + guJje5wDM7bLBUIu wO8 86.7 1 + gUKV6ROlCtV9GNPkM3w 0FU 7.23 1 + gUrg1FzLkbooCBE22WIg4 SxM 21 1 + gusEY3Jn4eYrpelKN GVO 47.37 1 + Gv73AOi3n6w811eomSRj wRX 65.81 1 + GvkTMzGc4svwCmYaMIeJFDE iLQ 59.62 1 + gvSYL2kDTjx5150V1D5B2I aHp 21.24 1 + gWXcbNTDbDW4pLxQN5A O47 96.15 1 + GxTE4TZEdPiuB6N9mOCQB dmo 25.21 1 + GyVEetmIcJ6fP2kHGEq 3YM 41.56 1 + GZiE22zWjXdVKuPGh 5kL 14.06 1 + GZvjdWZKmC56ZcCsUT25cT QuX 4.69 1 + h0pWROTb8ipNNPDQLi2051k AEE 23.92 1 + h0wcljP38NtCfWlQKeWji OE6 79.83 1 + h35IrwBUXTRIDtRF 18m 17 1 + h3s7EHQkCrYLpxo nY0 45.18 1 + h6LRC7dwMCl2CJQaTBNlEOKJ Qor 93.35 1 + h8RjoESuZyGyDVXyK 46e 14.13 1 + h8UPMYMGWcN5P1z1eaYRl dzy 37.48 1 + H9CkWXT1pJzsSFec tuF 10.04 1 + h9hdpGErcPLbLbEY8RfNxk x7K 19.26 1 + Ha1F2qejGQlTDtgyHxMA3 f2L 95.87 1 + hA1lXHgPGbLKcS0XG oPF 51.97 1 + hAdhqUNLC7oqNbtwNz 2Cx 15.37 1 + hb6al633PbyzEiSluDhy8q aCr 34.61 1 + hB7peFFIHN7EvgQKc5qqHzz YG9 57.44 1 + HBEKMzlxUSdweOlMTQ6BXVx 6sJ 77.76 1 + hc6cCZUTgz3YSWkZ3DS Lqy 63.33 1 + HcwWn3UDpvEj4RUnInVLK MFl 10.47 1 + hFz013C0fFFd6HIMfth8AEi mn5 14.36 1 + Hi8VoPf1qW0j6mvsMmCgHWAg AP4 15.23 1 + hIR3LKeudaVVMqmHr3lKjTOj wHA 25.78 1 + hJ8mOg8mPy2I9v0HmzZC9 S0z 2.48 1 + hk4mZI3SF2UubimAnMg3i Mcn 23.69 1 + HKRnrsgsgCcnpX51Okx9b4Lr sor 67.91 1 + HLJJl5jSsxF3o32 uqp 95.36 1 + hlY6G6OkrQlKpUKvx Mdi 50.98 1 + hMtBlFE2zJyiq2C750AJv7ka by3 52.75 1 + Hntwm3wq5XLM7zA UYk 19.64 1 + HnU56EFm3cfhV633K bYU 65.4 1 + HpLOzAkdn8FOHzT amS 22.04 1 + hPZJLAz1KlsLZok9 DQs 46.24 1 + hSxKK0vhNaSjPVX7Ce3KjhMP XGA 87.44 1 + HTp5tNSF2fGwUDB3W4MmOQ 5ou 8.65 1 + hTSKR6g5foDADbVPsoSh6 MG1 80.5 1 + hU8wE9aFQL1JBTCP 2hN 84.82 1 + HvGYq9LUleLAYUcpASlD xtu 58.19 1 + HvyuBEjAdjIuZHWqro tCT 32.16 1 + hWbG9bE0Wp48BE08P7hb m7S 54.19 1 + Hx4VG3aN7HF1gIA89cCXoiMm vUH 78.66 1 + HXzvDkiu7s7lpZ s8D 25.65 1 + hZldgiYJTbp0aoA2Nb1h 3Jb 46.95 1 + i0JH6SycK19B2UM1V4bidJke cGO 87.27 1 + i1beqaWK1HPC00z22t3hLrp c3s 37.25 1 + I2BEHEOhPMz2haCpROzCfpy g0K 48.43 1 + i3uMfHMSYlwlRdAqYHJOB Jh1 26.39 1 + I3Zkc7TaoqGFLynMr X0A 76.1 1 + I6PVW0ObtbHri67iGmMh DYP 46.71 1 + i917yWGCtlUeCQvv2MlfD NXC 80.38 1 + i9dJeWHcp5H51O6yR8 yxH 45.27 1 + i9ISiNUwd0J1lsHt9D uJh 70.68 1 + I9ZZKPkBhpNQFYDGiuVdR 8yt 98.81 1 + IbTttXxw8rgwERXGX ybP 9.52 1 + IC27ylaaiqgLtoufN5v pxn 81.34 1 + iG1QCd7wzYOuwJ0jM ZYd 75.87 1 + IHBjAevGAWi9NH Byn 71.42 1 + ihHMDJNMnz09bZXfk1esV nvn 15.8 1 + II98dtbPbqzVQFbJj rjD 59.96 1 + II9jdUUIdqWJzulv8jVrGC 69A 28.72 1 + IIBUGz2aTlI1llMg01c9 mYX 49.68 1 + IIoOYMUof9FtQM52nruWrxC if8 45.5 1 + IIthPPGZodKEqF4V1RB h73 75.97 1 + ik2QXWOdDZVRSq7RVsqUs20 9NF 53.81 1 + IKPIUJW9FaErxlMB3pL2m 9at 57.77 1 + IlpAStDgUghswvc64 fOi 76.95 1 + ImtKvvCBpCcU5lP wyD 67.06 1 + INepTWy7A97d36DYf VBE 50.37 1 + INsC1jNtsamIwGhiCUQ XnI 49.76 1 + IooWqqNfBWfVFfo QXK 63.98 1 + IP4IQvwynyjOcs3LytyLj1rg u67 63.21 1 + Iq0jbJo6iysS1WaKpQJ5CTjT mov 82.41 1 + IQasbB93zcZUfc9E208zyn t5j 58.78 1 + iQYfjb1Z3NExsNab2B5TL TVT 61.17 1 + IRQlEhhRvhsUUiG3t0O 8Eh 40.17 1 + IsJ44FV3wlOxPLFy 5MX 79.13 1 + IULk8S7Xao940y45iW od5 59.43 1 + iwcT93ufn2B7M5 ori 35.24 1 + IwEzkofJ3AEyzEynqGYM2KeW JaA 92.6 1 + IwvAdQtUeP5uGc 6qJ 69.86 1 + IYgLFtQBVB4NrgbbZs7 LyH 30.03 1 + iZ0rQDWFZDRkpd8cu5LO nM2 90.78 1 + IzbpCXtzU8qKLX2Qnz2jhuf 2MA 50.09 1 + izjZOirYviwBIYCJf8TK9 3MR 80.61 1 + IzMGHgPDjp0CZ5eKrBub SCn 12.87 1 + J0hyYk9P3uJ83N4U bC9 25.38 1 + J51yrkq2EbzrDWKF5F2 Oaq 57.72 1 + j5DAOG8B4uJKVsWaojSYhg LKH 82.56 1 + j6Y6cSZZrymxsFc2 etI 66.55 1 + J8raIctBuVtr32tBfUW 529 40.68 1 + j9J2C4xHsCpHqIC RIQ 22.82 1 + JaaAXHlv6215ojmszfUpCtn 22o 94.7 1 + jAHs7ejqa3AZI0iw Nx8 81.71 1 + JBVsyj1w07B2GH hVQ 76.01 1 + jbwjDKSPi1aSfODKn2 frY 98.09 1 + JFU4cSQZHoOfLq1vUWxEq ING 72.63 1 + JFYBegwYX1am8w43jzKO W5w 85.85 1 + jGClFsDo52NZvwRJj3RE6P p5Y 25.38 1 + Jj2zRl4A17PMyvO bSb 73.86 1 + jj6X0MHR2poXJN LuK 60.38 1 + jjarCgSAbAT6rG MhY 5.81 1 + jJp8KSiZVCrej2mX uyb 30.22 1 + JKb2RyFGjidyp9teM rfB 32.21 1 + jLNs6gczzjWS24XDgqZxy iGp 2.77 1 + jLR1L4PRfsVCik gBM 6.84 1 + JLSwl5qvOtFe8Tg gu6 70.5 1 + jMGD2Mer803aBGExl9FaD F7M 43.51 1 + JMIryGgu5gPdQy 6aH 44.89 1 + jnd7RfZQrtwO4ZkhS AXw 51.71 1 + jnVHFkvTmqUXCm 1o9 23.13 1 + JOpTjDGvcqn6ce0pQtToPO wyx 28.92 1 + joYF1D2gx4aZDJL Let 98.47 1 + JPFED6ibtPrfXM J2z 7.92 1 + JpGTI43TmzE0mMxy JMN 42.56 1 + JpiKYYF7LnAgirAbRwzcI CiX 9.11 1 + jPnDlPtfM7Z9xUbcQK5GUt78 eTl 66.22 1 + JPOuL9XM8O3QTKXVeux96s ODZ 8.57 1 + JPxjefMXcHxMhHGlnKhP0j5 hCr 83.75 1 + JPyhk3kyBhZGUskKjgteW4gy Hql 6.11 1 + JQNBF5MoBQIdn7vKZO K9J 97.21 1 + JR29ivcK2xxlq8C 2Qo 82.19 1 + jRfkpxXnTRuyWTe6z4qVd4dl hTE 35.43 1 + jrqvSepuV66EWGE qVf 56.22 1 + js2VRcxAqbUdcIo Mic 74.43 1 + JTQM1kgzYQjbEswu4zrcDcH Y0A 74.93 1 + ju5cyZOMHkCEBRQeEQ7LH1a lph 79.34 1 + JUhj7Ch8XSEYCvHoDzZ Fqi 38.46 1 + JV1BoOxS2JenbE 6vc 4.67 1 + JVz0f7DZ12nY7SSRApSa pIr 57.36 1 + JWTxmZmnbdkdKMXpUh 8p7 93.54 1 + jY8NWI3j4hRW45 IxT 88.93 1 + JyTJKiM6KSUJrK LWd 87.51 1 + jzinJ4R0vsFHfrayOjTLdk Bt3 97.96 1 + jZxO1FOI7BYiT1Z kn9 8.95 1 + k0qAn8ErQcbdaAsB kzW 91.81 1 + K2AVgWNhEBFtUfMO wRD 77.4 1 + k2Rf2ysnXcfq0hTUp1e U04 83.2 1 + K3y8UXXqppTVCIEQ5As8CU OmF 14.35 1 + K45XeAB33PBmNvrR FBg 23.06 1 + K4iCGbrNbyQDJKjjcf3tXf zEc 4.35 1 + K631vkfNc2MCl5v PiE 60.47 1 + K76WylyZECiima4OFMZhfMYy hIr 57.48 1 + K7vwNusHXXKNci4wI6irz hkZ 33.11 1 + k83C17NqvbtRwFv99ystjjG BwG 45.46 1 + k8d4rHX37sgfugxa eHZ 12.58 1 + kbmeHbl7B2dfOkZHsaeb HZ1 93.98 1 + KD5OlyNyl9nsO5h2zzk2eQX Ama 71.43 1 + KDUNHnfBPw0yGG 0ul 31.03 1 + KFed3wlee7feEpdU dQu 41.86 1 + kFs7rTMsT9fBGk17K FHi 71.11 1 + kFwUJDVs8PUitVIbTccVLCsQ Gh5 19.66 1 + KHSWUvfX1zoEhPKsZ yoZ 32.12 1 + KIgwUY0g111nbhN MEM 32.55 1 + kK8NAPIOLrysH05hpuEcf2K Jhh 27.13 1 + KLmQ3VOEm9aDwthuuAy 7Ke 57.67 1 + kmguCIqw5Uwj5O9 3xN 93.76 1 + kMO7WlpELX1L3V fIi 64.48 1 + kNEHkVKYtB1oBFDfyN qN7 26.54 1 + kNN3Y9vFapW6AQi7Iq 73L 31.7 1 + KOh5KiTnOUhFm9P4PO1 z9X 4.51 1 + KOr9ndPJ7CMWutBPpoi5y VRn 60.95 1 + Kp4N4BFiCdROBY D5i 28.25 1 + kPmFgyW2JpBkyuPDEV XYx 45 1 + KpMlCvjAIUPHZlrDYUiVmq eIo 75.48 1 + KqM4cCFOzeUnismzvfil por 32.64 1 + kSpripiRtRzEgqCeK6 Z2H 77.04 1 + KtEU2TH6ux1G6gqDIDI t9Z 91.35 1 + KTkMaURJWWTFoxQHxo NFZ 71.11 1 + kTvKE9YjTLE2fqq rOJ 34.95 1 + KTxSQAFHRgcgmUXNS SXY 19.81 1 + KuhmGF6tKQP7Fr u7O 81.54 1 + KvZ0CwcvxG21Sc CCx 37.07 1 + KXOK4BPnEVLuFb4ictLM6 YQt 30.3 1 + kxUO0WQNUzieeFTryflebY Dtg 84.79 1 + kZf5TBY3Y9EoQlGLKj30 PvM 56.39 1 + kZipybmtluQgdWdrHnvIFR tlA 59.43 1 + l0mzimgwlsXqGUBgM nG0 85.26 1 + L1AX0HxaeQwNJpaB op9 41.5 1 + L1c3MnszY5u1jMGPXLRHxHKq yX1 46.66 1 + L1FJOUA1VzjbgJ icC 13.78 1 + L2hwVRboEbZ2hPb59vDasXF PCK 92.22 1 + l2QD3Yi4varknBZ90d4P wHG 8.99 1 + l3K8eizT2TIUALIMiSW4P Is6 1.68 1 + l4uiTfaSCWD5rwe1uY1 388 90.01 1 + L744BFfiGgsmDmc9tyLVgX HB7 1.54 1 + L7LAPsZxdrjNdpv bw6 23.21 1 + lag6rsYOXDcrxxdYq8k I9s 57.6 1 + LAtzLcslJibFrX7PGdt Wyq 87.19 1 + LAu4X2aPmXJdUF 33C 45.67 1 + lcU2uPCkdf1mWyawJg9mR8 9Ft 21.7 1 + LcZRYcEeaHZrtZ6dsCZSd lRs 46.88 1 + LD1d9zdYvNiWvXI2J f31 86.98 1 + lDnlB0YwIvkkGoe5x cio 15.7 1 + leawxU0mv8nsapdNNqr y9k 23.25 1 + LFzgAjXqOnjPECBcnkQ2WMY DDA 83.19 1 + Lg3tN2xbGorr6lY IdU 79.53 1 + LGiFx7TXtSQ8qMPxhR sOx 79.5 1 + lJfAJ8RJ1sxsbmQS2Ck cPO 17.72 1 + lk0ed5qKtxeiC5144l rWw 95.73 1 + LKhqXVu2J2FQIVWq1La CnY 86.27 1 + LKKyv5Iyyoi7rz2x t9b 5.71 1 + lLgZ2NC4JVp5P9sa1d x1F 60.02 1 + llrP3gT00Y8KDEau68e 4wN 46.28 1 + lMahW3jFsjEElYo13nxgfI G6l 1.21 1 + LmImUmfxTOZ6v7Xjlh eaH 6.11 1 + LMWoF7u9t7JbHbpCG haI 6.6 1 + lncie89pstAvCdIw7c cxL 46.95 1 + lnQmPf82CqN3qRTELyV znf 34.08 1 + lNVGlfZMxDB19DZy3V l3T 7.36 1 + Lo29dO7aXKBXyIS8GZSY fpP 14.33 1 + LP2IilM1Bhb6G0bzkQJ sb1 35.81 1 + lRx8wX2RW9W4if0xAWQ 58d 88.32 1 + Lsdjj30h9qW8xr0h2 eb5 68.2 1 + lSg7tHj8Qnba502zVi Was 68.9 1 + LsMfNe0WiYUttGIiGdAFSn pla 16.94 1 + LT99XhaEyiECpTlgnjiF lDB 24.48 1 + LV0L9ie1oECNbu44K sYN 56.05 1 + LVg0iiaxgCaEEVqaDmwoZ V5v 29.13 1 + LW2MUWf4IsecVn4cc uNM 29.86 1 + lW8ht52DgEgRKbhV q1x 7.43 1 + lX3Ycw3Z6b65pLNM VxV 20.37 1 + LxblBQ3wDGor7u sHx 42.26 1 + lxQrkMtX6g3B9PHCYT6mjT n6e 24.3 1 + LxR1rq2XAbl2LaUfP4chCpoX si4 43.44 1 + m01ChpMoux1Lqlsr1wTgC AVt 12.43 1 + m3CoTJzGkqoWPOKnR pKT 3.76 1 + M3yRj2sHuDvtproRlaVip3dM nqM 26.02 1 + m5qiy5aSrDRsPjYuK3 oLZ 57.71 1 + m5tuJK7D4QfkTwNM4vvWkJTz ori 49.82 1 + m9DtL2Ki8CdBeN LpQ 51.53 1 + MA9cCxBUNSNS7vLD3 AYW 93.05 1 + maQHUnit2wH5w9oKu4 yIq 42.08 1 + mb8oJBj3rEctyGAoWvseC YM9 51.9 1 + MCKikjTvGD6rEIIKuLONqq GV0 76.6 1 + mCPMhEMo05eNLs peD 85.42 1 + mDvI5pU9im2ZfE Hm8 33.71 1 + MeE4R905c3IEc5 UrK 47.12 1 + MgJfIWjYMJq0VAnVvQ O2j 52.86 1 + MGqAVnbVEsDaVeHy2kdiB9 O4j 65.72 1 + MiRF9Bkua7JohTmax8kzHKG XRn 29.19 1 + mJAy4lJtNLmBVvMu tR3 14.12 1 + MKPdSLF3cFvP92N CwW 86.39 1 + mN3RoRjh5lBfh6vuuSl2 b8r 36.48 1 + mngVTPQkazW4N0sjj vGH 1.81 1 + moZcAiO3KAuJ87l 0iW 40.04 1 + MpeUE0Nuims5wo KbM 41.58 1 + mPVqvyomHkvBWmtRgbM7FIB YWh 13.5 1 + msUeoyhGzGbFU41P2N4c kO8 94.7 1 + mt6pXBdIqwDKSnADdA4B rEX 44.73 1 + MTkOZ0RKmTKD53v 8nv 92.39 1 + Mu47DfHKYL6EtWFGPjz POq 42.36 1 + mUwd6Bxd6foSy6m Mri 61.36 1 + mVDyAXKJMJzhxVVIBVLE WQt 45.47 1 + MVkL1oR9l5LRSSp1cHV9Hq zRW 81.43 1 + Mvw5mfPdCuJoj3GImkgN0O bGD 30.91 1 + mX4gJhDnsTkARcg s8k 36.96 1 + MxBWAB3VSB51xn5mi3HRn7 bFd 66.65 1 + My7wIbRAEvJNOpXkOFmKf euI 9.29 1 + N0qYmHZtAsvfo1q Agy 19.78 1 + N3NgiuL0AoTHVNcv myL 91.48 1 + N4clAb9geQtpCyqoL XCu 54.62 1 + n6JMwoZhy8DIv5 ADO 5.42 1 + n6MevHte4zHHaG DM3 11.35 1 + n7aLzWfnUKnRqCE 5AH 48.76 1 + N8khIinkvcNCNzKrO9SFGFW 1JB 66.81 1 + N8mGSPek7hefjU8NFOGBEje fdq 92.38 1 + N8T4KDQP3S92DG5ylQ stO 97.54 1 + N8WFFwgUwbpZLj1koJIrx56Y 3Yo 80.99 1 + nAwyOtDhkko4E7I udX 44.28 1 + nboJrtJYV6Mt3zv1B4Lr9 e0c 73.16 1 + ND6Qj0uJo7PNghLG AIg 80.56 1 + nDHKPelpvbdCQ1MEr7q sZx 92.71 1 + ndv6b86rKp9n2cNX K6g 47.78 1 + NdVlS2f1LYTVisDUJL 27Z 94.54 1 + NezkXiKM7UGbahAr Yps 46.09 1 + nFCPghrtwrKldJ7Ucez to5 16.31 1 + NgroNYddwE8yLuWvvnCAbHe yYA 62.72 1 + NhNfGaKlT91S7wev6lwvW ezU 81.62 1 + nhxGqyJtcmp0c2GS Wfi 9.96 1 + njbqCyHTsu8mcNXPIUEvBS6D 9iW 65.27 1 + NjPiPAfJzD6iQMN Ve2 5.17 1 + NksJ8Ql4h0Ey9LKy1vG6xt zUf 54.68 1 + NkydGDsNDYVNwoiOt8Yeky UEG 15.78 1 + Nl979aeBArbokbg6KalMkm b0Q 24.54 1 + NLChPAeLao3euOX 9mn 23.51 1 + NlqtcD6OXKKiTydgD5Ifc fuq 95.02 1 + nN741i5RlauzTT5 OB2 98.08 1 + noMRxGcZyhr29PjuwAosgc 4Z6 99.32 1 + NOxDr6tBFvn6AzXOq8TBCz 47u 18.63 1 + NpKvHp3fE1kKFUk A3B 33.45 1 + nPQ9MXF7AQQtfGHGLm8i81 MO7 97.31 1 + NQ1bCYV8lzlBuI3kxijPdZl jAO 14.81 1 + nQBItoA4Z6BRi9ryHZCJ KWR 84.01 1 + Nr2ATnsW0soVDcryfTx 9fb 57.08 1 + nrtf4ebujgXutVUQ24vvRX6A 274 90.85 1 + nry7fD2PxCq0cKcancYLQT C8R 15.81 1 + NsKTnVQ542CLpJfORRu hzk 19.84 1 + nTETvxx8Zx8rnPNO3eMQpNG GHx 72.1 1 + nTKqRKLVCtEAZHFRXGP ZAU 81.28 1 + nTNXT9GgQqd4SpUDlakQt YkL 72.96 1 + nU46pBloZd9IzLvWqkWw6KQ QKG 43.35 1 + NuPEY4TO3xEhJtyRAJM89 T7z 25.88 1 + nuStI9F3F0w686CyEPF EM8 76.39 1 + nUZAtCgfhJyQOrPha2A7 fs4 96.27 1 + nv01rF8xhf5mmD tVe 48.18 1 + NvdU0t4nciQvavt8haKWV y1K 55.61 1 + nVgbdsee2SP4FB5Hq2TBYep ADL 79.95 1 + NW1fTAdEz1BlUxLah2 WOV 86.7 1 + NwJuCQLeCrcbbc3 3YY 88.22 1 + nXUNnjAQqfCH7YbOYEF b4Y 18.33 1 + NYf4OsHVg3Y9oQaKEfi bzM 27.09 1 + nYk2NTiKilobkNAjz k5d 73.55 1 + nyvE9NFl2vmvi2mzHMwt UWq 66.45 1 + nzsDP3gGhpvHviTBiYm2Yeqd CLP 46.77 1 + NZsqwirp5YhptCqfuu yTJ 72.07 1 + O0cGuNyxio4wwvIW8v XtI 34.3 1 + O5sn8AMNXAxcF3KpyMJXZb HAA 22.58 1 + O6azxvTxZ8GZ0TIB3Qb8S5WC AYX 71.02 1 + o6k3ytLBgirhI9 tQs 30.6 1 + o6NQbq6fMGQZbsvY kJq 32.83 1 + o8o3MRUxYQIgThukY C2r 37.22 1 + O8ZabEStBdi9CsfsVAsZOTvn EuH 24.99 1 + oA1rcvMtJMM3WN3IjDTlrI nWq 3.52 1 + OaP8iZXC1pp1aFJm5s Fgy 29.02 1 + OBEZPeqo6M0hWyfTt7MB3i3r niv 72.21 1 + ObvRXd5zbUB6wcIYL4 gpT 58.35 1 + OCazep9pWuL9Yzsk54dJin R2I 89.17 1 + oCges9emvR1NY4J TnX 8 1 + octuE87qAIFUrn B0q 56.88 1 + OEDrGN6OTv6vhQHp1Tkc4myA 50Z 85.93 1 + Of5BpUWy82CL4oeF4V 9wT 54.55 1 + ofkxBHZUOGAPOxTYDP who 25.68 1 + ofOxLC6d6EzopbXCUBC hxO 22.95 1 + OfufPCtBRzzdmmqYFUA3I0 G8y 18.01 1 + ogO4DXOCOmZXKxoJ4atHn0 Zpu 88.7 1 + ohl2bd2nFU2jBg8 2AX 83.93 1 + oHmIL1TqNdobgO7di 6v2 4.31 1 + OHsMTuqtHz6We4qEH 5ND 23.12 1 + OiCrNbNSFu3BIcKr3HXuBZ 1SB 17.54 1 + OiKsF1LwiVA6Nl3eMr x7C 67.43 1 + OJ0bjqXzjQX8u4l1KB7h1pU Mkb 13.41 1 + OkdHqmZSxXiqxCzmBbO SG1 67.64 1 + Ol0NYDdm3hqxDUN8gt04 cyI 27.14 1 + OlqD4h1xsEkkcZbbu vI7 57.32 1 + olS5kG6EPR4IZ53q7 BcF 96.7 1 + OndJRMmuEHmumgwSQ Wvv 81.96 1 + onKlpy2g8wCx2Zy c2w 66.6 1 + oocJRss86l5uIOqT8BbpokD LHv 11.27 1 + OoKtbEWbxXW6ao vPa 77.21 1 + OottD147HMIqmg Wfm 61.72 1 + oOxyniSQg7XkseS1dVQuzF PMg 74.39 1 + OqwlZpg0tmTThxZUFz2DmgN dIN 22.97 1 + OsST9j61DJ3vNlX3U JlS 70.54 1 + oSXPqILMtxwLj5 ES3 14.5 1 + ou1KaxGwHXKeqEnEIHu07JYo 1we 45.35 1 + OUFrIkHduLknIyp kRS 21.94 1 + Ow13bebZXKyZx2LwzUnyUl iZs 50.86 1 + OW1MtAVyNmiwmIeM8Ru PXl 48.61 1 + OxL4xjvvEoakC6o0SWFzLv bLo 10.34 1 + oYBlXuJnf0AhIT otr 86.71 1 + ozEs5xfkNSaBSctPlMAXfLo tzR 87.64 1 + Ozz08niBb8usTCQ0Qne uze 84.45 1 + P2CnLZ6wjMWagfa86PQ SDk 9.75 1 + p2rOb9TRfrpmEB734J3K 4oU 12.58 1 + p3RrlAVpzgYG8j0C CEX 89.77 1 + p9jPfGcJVMsEwYYpmysYL Cuo 98.66 1 + P9jWWng639kr6huLW Guq 85.11 1 + PaX7a2ZeCYLBeLo0Ywb9QUF uA8 21.31 1 + PbELYJY6EYll76 87T 95.96 1 + PC1Xwq9khOD7eg25XNuJqni uoa 93.72 1 + PCyvr6u2zEucFvBo OEh 97.69 1 + PGjlCUTKvUARyWdB k2X 26.42 1 + Ph5tQXDBnhWbTjJ xoo 99.69 1 + phaRh2uo7SAM3S OSi 55.68 1 + PhzrsGUN9PoBD3mSwcl6y ciK 47.26 1 + PiGGeRPSYxRyw1NKij8r mx2 11.52 1 + PKKgsHRrVuEwXpXdE2k8 Th7 91.23 1 + pKkHlorQinRSRQJdZ0fYM Ye8 83.24 1 + PKPztQnn95S3qiy1X2YM idK 18.76 1 + PltQR9dIYwROa5 wK5 2.76 1 + PMCzdqCNhX7NXHrWGDd qWt 55.65 1 + PMHOGU4zGtraGFlOYSc7R9 f8p 41.27 1 + PMIqODa6qLNOD5KOI oYu 43.68 1 + pmivv2mZoqInf5HYg uor 82.4 1 + pmSlPgZ3UbACR1YwKx xvS 74.25 1 + Pmxcw6cnA4nDap LPf 35.73 1 + PNkk03cra6W80jV6oDXizVgX LRm 35.89 1 + Ppbe1YE5u8tDy5JwDIhkDnYq ZQI 27.39 1 + pQFtR44HoQ4Grd5gQTB4bR sCv 11.73 1 + PSmNJYz7MMCjgAaUzyeKumP6 B90 20.36 1 + pSmu76DfLDpInp9 Y39 53.77 1 + PUAA04ZRu2YSpYSl3Wp7JxfB 37E 38.54 1 + PUrCSgoSOWH2UVl D2I 67.64 1 + puu3QlA4QIaWKE3KrljJpwA xoU 72.05 1 + Puxk5YIOcdh6tHvlaJ0gy WBV 12.66 1 + PVfFRi1A7ODcSgYSyp5cfx prD 61.75 1 + PvNGMvjloNOzkY7R Equ 95.02 1 + pVRJAXJWxBDOPwHyZKs7INB cj6 10.03 1 + Pvxw7Ts6nCrP4TSp g7l 82.75 1 + pyHViBYExLdKV4E0k ERy 90.25 1 + pYlDV1rHMwOZ0j9TTMKNUeY WnO 96.96 1 + pYW2sZ7IEjg78gvea9 AwU 35.97 1 + q04Ybp9gtmpT8RXwiKxqszj FjG 52.08 1 + Q0jVg7u6A4ZbN6tQlXsjXSq kdb 28.13 1 + Q5VAqeLHs69lk9wfRkRcWJHU cy5 25.63 1 + Q79Rmfepqv5lzL 2IE 44.18 1 + Q7DiN5QUywPkHOoH jvV 20.57 1 + q7ZUoEHOorsjVLz5m9F0ggew f00 55.62 1 + q8rdaB59K6MKmtqNW TLY 25.54 1 + qaf7t83OBruktJ9 7QH 20.49 1 + qaP66yKXl8iuXduawPFxe bg6 38.91 1 + qC10rKozjpso8r6dxu chl 7.79 1 + qd9PzUTlhjEsekV0NUo3GbCM BIN 55.35 1 + qepymlgDIndNoEaR QUX 18.78 1 + qf1oZdzGr2W42i70kaNuk38 00y 76.81 1 + qf36p9CoGxOXIQ 1lt 66.28 1 + QGdgYHj5LhGDUvtofp dxC 88.6 1 + qgyo23KYSduq4rSGhmZdy dCE 63.24 1 + QH8G0J9UW2twj7 Foq 78.92 1 + qhXD45Ge8KYXVKkBnl5AnUbi C2s 28.29 1 + QihIjz62Zu66Wu puu 25.95 1 + qJ29mh3igLo8PL95KNtLf lt1 25.19 1 + qj3HacO8gluMPy s5V 90.65 1 + QJje68AM5qxMkahvEy6 Vet 72.86 1 + qjRCy8w2SpIYvDer3RAqu xYR 86.12 1 + qjVwvkToI6szzA7DjoYr7 ori 11.16 1 + QkKno7wqhsBq1MCqL YOp 66.26 1 + QkoYhRYWtcIxrAlYG SrO 53.02 1 + QlrPeUnoW8XLUUoGc3L zwA 95.45 1 + qMbOMkCscVI3i275oLoA0w Mo2 90.16 1 + qmMUUOHzOp6AxWvSI7tkK Xay 57.34 1 + qomB8fW6cCL67QXogBSk zlI 88.05 1 + QP9NsYKE2oB04yrnpiM0 2xW 39.66 1 + QpXjh9Z8XiB9FH3oTCxoV2bm Sk1 45.99 1 + QPxvlmw1it4mQzt G0Y 21.56 1 + Qq3pEfIwdn3VriDZtybfx XWF 44.47 1 + qQebASxdzPNIE1J9Voe MDZ 66.49 1 + qR7Lk6AUzS8k3U9kyfV3 hus 56.42 1 + qRFzkyTggJkNJJ fgn 4.13 1 + qrvxcAkdMe39nfKtmdj5eW 8iV 8.77 1 + Qui5WxWbdp1oIFfLzMQfA Q9N 8.9 1 + QxEgQF0gSaXpf4Y 431 87.6 1 + qYf4XNzDv5vUlz ZOq 89.64 1 + QyIkFBfP0PBEILVA2G7w3 PcE 15.3 1 + QYRfBFTwI6cynn5 hoE 90.97 1 + QYwbI89e9ncnlJOJ9oM 6kB 18.5 1 + qZhtNICPmT3xbeKdk8K1V0P 7nR 95.43 1 + QZpq09KFrQmOWTXOT72uXc3 xvn 51.68 1 + QzUJlNEyR3fVgEX 9vi 67.44 1 + r0FWekbHIqzVzaJl1EIGWGsF z6y 7.73 1 + r0nHYC6SwliA90MXDX JRc 30.08 1 + r0ToJLZC6ggPDyQZnGP 0Mj 39.35 1 + R25vnJLr0nsNGPt ZMS 52.03 1 + R5QwgHd4HKdbOZNZZNEle Eit 86.44 1 + R6le82FzuhFP32ErHkToRZ bHI 4.95 1 + r6PPkA8fr6WSvi7A BTw 57.55 1 + R7Fydl21yZkUNQe ZkH 65.71 1 + r85iRmJo8q4g35Je eFG 43.88 1 + R9UtaZjUQzLToiQbSRGHK TxC 41.66 1 + RBQCVWthwHFGvSOGTFrMNKiq CY4 55.51 1 + rDNSGptsMtRWWC7Ezy7 3fz 88.06 1 + rdovPcFy50ch0vNKQ8hkJE Xeo 96.01 1 + RDTFeq5N4KriyXs0kmtlYh 3VO 1.63 1 + ReFnzIkgdrmsLw tuU 82.35 1 + rEMmThyMzZGfakSOl D70 75.69 1 + rf6V0JeVzw30yvdD9A3Dncp GMX 86.67 1 + RfGAEq03TSNRARy DDK 57.03 1 + rFmeR8mqXfQf6E 6pm 97.84 1 + RFpiCoSHuttttFnw4yd OZe 8.07 1 + rglgIlDapRkVgx0GVIJL2vF wmb 18.76 1 + RHsx70BA6w1pNyKM4G9Un6a 6KK 47.84 1 + rIQEnqBeUWYwkHtHCXFbJte8 a7m 91.61 1 + RiVtvCwEiwt0N9OnBwyVwMt TrE 26.52 1 + RjyvNSmXxrxFCWcdPHIOp1i TZw 61.16 1 + rKgzFhLYAklXz8S DBI 77.2 1 + RKS4ZEeZN5Ugo11lsJJCgQRS 0aR 39.94 1 + RNgNrHBFdqeiuBPae41kphfi f7x 89.74 1 + RNlGLeD8Hj2nF0vJ J0w 5.94 1 + rO69pVIhbbaAcs jyL 94.95 1 + RoefUWwzCtzEHFVoQe 1Y6 15.25 1 + rOl1hlxGDZbRZlJfLoHjwM4 f9m 49.15 1 + RPagzGYCuPXB1DiZn7 EvT 75.83 1 + RPieMYuSQPs5BuR51YJPRlF kO4 2.08 1 + rpYWiYZfjTIxOr Dcc 75.34 1 + RPZd1QfD1Oz4pvQWTcEl pUC 73.56 1 + rqBJSV5ieYSGSTg f7f 11.87 1 + rrSnOo3FgAlq8mo h7x 7.49 1 + rsnpStePhGJ5cbc0Qp LXX 2.63 1 + RsVtYNU406AKgsJLXI NL0 6.11 1 + RsyBqiILwhYlasuYrI8zrBl9 WYa 7.26 1 + RSYuy2llNNGOftOERZ1 V76 84.41 1 + RtBTDYJ1M3wvZ7 WTZ 97.08 1 + Ru6QVmdahoaIKo dno 38.45 1 + Ru8hSBqNF1LjhI pIQ 4.2 1 + RUXEoEj2aQt1BCKFNSZt s2l 13.29 1 + RvaLlDEILeVs8fn5y9x4dhg 9Rl 22.79 1 + rvNzzk15hv27prn0IUt PAX 37.15 1 + rW3o2WyHQDzlxkBk AWo 94.21 1 + RwSCGJmUGMENAt JWQ 45.56 1 + rWWNfX5yWNi1d5j7Epn Jx6 36.79 1 + rx5Nrmnah3H12WtEpow WtJ 57.16 1 + RXill3VFEZ8EqjWjt6fGUiP Xll 45.82 1 + rXSKiGRzK1sbXN97a izQ 52.88 1 + rzBXDyD76WdnD8MMINzi rFK 71.33 1 + S00J06OqTyeNoGLKbu3G7 0Je 18.06 1 + s1Xdx5NRTT8P4QjS Joa 92.56 1 + S2VqQgWqhS3RoVlviTr96R htK 32.75 1 + s3k9YdBgCZChqqc2KJs0Rd 02o 66.93 1 + s43AZxvAuX5cryV NeL 7.71 1 + s4XVPloxW2sntECc3wEAPNA dMU 72.57 1 + S5QQcGTJ2Ru7VhZgh 798 49.49 1 + S67tRr7b6BImHJTYdbYGGUi s6y 72.6 1 + S8jTdmsSW6J1f24rSleyfw Hca 18.29 1 + sBAie5QHzV5fx82Zq9gzpU OqZ 32.24 1 + sc5aEYg6zhHbgthY Sa8 30.04 1 + ScgBv0aPRCffHo jgs 63.59 1 + sctez1OUXW0NHr03pfli4U lQA 37.21 1 + sDInbdYgzmGPxpJLSrxdO X8O 53.08 1 + seU96HzNN0fwMfYlDJplU pHf 94.91 1 + sF3z0wWUD0IC1pH 30N 59.97 1 + sF4gpiUnSfXXcS3 TIW 81.31 1 + sgc3SU66nhw24xmWNF 58R 73.4 1 + sgjGMbb4FA9dHaf lRa 34.6 1 + SgRgaqpdUruKTGIBm ouk 64.87 1 + SIJ7JVaRxbcXah7rOAVJQKLt ldj 87.77 1 + sj4tIRIyyn3es0jDtk8qF 4wO 67.79 1 + sj5Xr7qzw35utX yoC 25.68 1 + SJend8FY7yKDsn2X T85 90.81 1 + sjPUoLHBbatTmtocHMypO hHZ 99.89 1 + sJtOMpYW0fbPeLltexDrvLh TJr 44.57 1 + SkNbDal7HKaK5MzvRhLL 3AZ 20.67 1 + SLfsxEDW5U3bQedV34KRyQ aYL 86.24 1 + SLhYnLUjIPKFhp5N1BZysTvu UhP 79.08 1 + smwbAhBCUACd9sdJFWz2M833 Yyu 43.65 1 + smXsoV5mxxJyxo8 bMm 45.78 1 + sNgMEXHDy2xYhk6gRX3Gy yio 86.8 1 + SON0p1HBKsEKycIO1 403 62.97 1 + SpHmNpcYtOyMlaS9 KgH 38.16 1 + SQ2WhZJQs5Un8X4hk4J LY0 90.42 1 + SrETF87YVmopyoCu8vIa wdi 93.73 1 + ssHSCI7qRGVoaarb79KXz4ob K6M 61.93 1 + ST8CO1SdQaNA76lTZKeM Jps 27.02 1 + stxqwGJbgJeLb1mfY 0aD 25.79 1 + sukmVIXCSn67vVAlTet p4e 16.01 1 + SuMKUpks20MVLNw2gc DQK 82.91 1 + SVCznCfaGuPwfc VFF 87.31 1 + Svv5voiLn2TVRUDWmHf Wx6 27.4 1 + swZiMOVaMB8L6DS4 MS1 6.44 1 + sxaxXe26hFT1Ibb XBF 24.83 1 + SYpRauEMoP4FebQKefDOqV aZ7 12.48 1 + sz0NdgvFy62JNTU 9yD 87.19 1 + SZ9Qux4zKykbLUFJKk6Bi1nB YwN 77.6 1 + T2DOnK1ew2Aw3KbAXWvvM NVQ 27.54 1 + t3oHSHrOOQMVEP vnz 78.27 1 + t4ccklaRBqjFXhCnH coA 49.72 1 + T4CuDNhqqNCKJdnaevz3hHq t07 17.65 1 + t4Zc06ibr46rnUo XKB 38.2 1 + t59WezBkpcrvXagU5feH yCY 10.33 1 + t5coKomHaPANbfKiy2VXtL 4xQ 69.49 1 + t7esI9bupiR2eHMV4WLpc6J0 TQU 9.68 1 + T7Pzh7yR6mxxXhPoL zwd 27.41 1 + t9lCi4dHew3BymRzyNy8nA9K scP 69.27 1 + tap9jqTTMyXCU3xh9 xG9 17.67 1 + TAXWVFRQdqpOGlDSPN aLo 59.75 1 + tBfoqUZc3nKcKLdDnA8 GDs 31.12 1 + TBtoqNTBknbpS0ThxMFS 36z 60.9 1 + Tc8NKhKKj8xUfoDOqX1 40H 49.57 1 + tEdzF8kghiu0yyZJ0 lAO 75.3 1 + tENXvTd895E0pd2F2 EjT 23.77 1 + TeQjJV9teIv3JtDnPw 6KD 75.99 1 + TEQOQFcsU6yhrUldJFj5RdSL 99K 53.71 1 + TeYu1aOQJtreVBwcB 4QS 64.69 1 + tf54wabdRnf3NHdYVxzOg 3Vc 95.26 1 + TF7LQG2WKvjP7WkAFU A1O 54.2 1 + tf9IkWLlXKssLH dSE 72.18 1 + tfdyDbfuq3Bfqem4lq lJG 47.38 1 + TG2pqiRoYYAg2Phu2x7zbI nuo 99.93 1 + TGBV9N8TbblmdhnXWCasQp uLI 97.96 1 + TH4UpKUwsroSrOxi ORG 92.58 1 + tHjOYdwyt7M5fL4hPuPo MY2 54.75 1 + tHM2V9ymycZdRs6ZPcG3g u48 36.22 1 + tHnsNjID2XM0QaCrveL2hHxW tgL 65.35 1 + TI4rpz5Z8W7YeQofKFjgEBpz eBf 40.57 1 + TJPSkSKyPbcxt4RM58t2JhW ror 42.46 1 + tJR3s3j9B7uEIRqrzfEVYe2 u7g 21.3 1 + tKeRiqmX72izEGY5Tpkxj KXB 92.34 1 + tKKJfPuqcrfPcCI 6Q7 17.08 1 + tKzof5KSuD9KU8o5awGpm0Pz Cf3 44.76 1 + tluulKWRrloEkH L0D 22.68 1 + TM76uaNv4HFty3dNT 5MS 94.57 1 + tmf6ThzUduSQkMuu N7x 30.97 1 + TMJNgyJGcHo2bzoM az2 90.89 1 + tPBmfeclv9j6dVjMkiJj2X 2B1 86.19 1 + tpxXav2iTngSHqySX5mRDHD iKd 27.79 1 + Ts2tcICOYSfqLi 9gA 88.85 1 + ttBaqvlboRG9ha dlv 99.47 1 + TtCoQZdOcnG7Jpjt7B3H9BJ0 Sts 32.75 1 + tTMz0Ce0QrqET2WrpYjYO A6g 83.68 1 + TtOiVmaPwN5yMAd fCv 84.22 1 + TUClmpnVo3kzSYFFLY86HIc paV 39.9 1 + tuNba31NCOwxD2UoJiXAOB 3Yc 13.75 1 + Tvpf5XFf18BkI2T cIC 86.11 1 + tvtglsqFLrIsvi EgB 80.26 1 + TW1LYUcQS2Dru5mp lQJ 53.37 1 + tW2FG2aHzlT2v8Jywkes3rt Kwd 86.06 1 + tYxPukj0QKMyqE3OgiD cnW 38.14 1 + TztzRsLodT2Pur0Y2nRtiS B2d 73.78 1 + Tzv1YxMu70cdYA9pWWR bI4 76.14 1 + U0DQU5LOcFHKXNqL nZg 60.45 1 + U0VOWotkXSJ2pzsL4 cH5 26.44 1 + u2jGziNyuAucmwjZct5xR 6kD 67.01 1 + U3ilJloVcABVb1A0K4fj 7yr 92.2 1 + U3LubhEKNJKV3J4BMGLCB YaK 61.88 1 + U49mC5p75BYblY0l5SxBI Fy4 87.32 1 + u4iOHwOb92rkaUAEmltGNgP ocq 47.96 1 + U7ErGpZpgas4Vf3SvDk07rf WyA 35.26 1 + U8XmpPbUnZwwtbJuCwa GR7 22.35 1 + U95gD5JVf5JEeGkmLczY 1NR 34.42 1 + U9FiQLmkZAiXMKkxqKAJ iHH 18.81 1 + UEfeL9Zx5kgpRtGDbiT RYc 71.86 1 + uesKPfmyaDjzmA3mvTzz osf 17.6 1 + UfK51ydwQANdJ4cqm3JmLGvP Qh8 92.16 1 + ug6RR5mud2770w jBS 37.59 1 + ugHT9UFOYGKLTF42Xo9T CVh 96.12 1 + UGZhySIbfZYlL1NTkvhEK 0wi 67.88 1 + UhIUbDmRt2CkXqx jEL 67.69 1 + UHJlvkLI7Bu8Ar6wnY9 JSA 68.67 1 + UhrJHgGdYfdnan89C JPc 11.34 1 + UIQISPb9lFt40jwszS1eCNMA aLC 38.44 1 + UIuTDjzpNPrh6nwqrG Hab 26.31 1 + uKFdauo3vYlBiM2CsUwTv UBM 44.53 1 + uKGv1g5Spj7JMfySDgm Fca 49.26 1 + Ukm94cZvYUAOjDj7 gqD 24.29 1 + uLAO8qSC1TM6HXnQqQdXep J0q 11.85 1 + UlEwPfof1obB6RpjtJ oRU 69.57 1 + umbDYpJJUBxZIFOghDdmK6qu HlR 25.13 1 + UoNwKuL8Pd8jxsMJh2AboNM i3G 52.72 1 + up0KitPCx9bACH1GSdk BM8 64.99 1 + UpWOpD31ZRm9hL6W lvX 64.43 1 + UQb4kGlQBaQuZjEgW4fdS S6N 50.61 1 + URAel0CqfSmFM3ZOpGxu 2uh 30.42 1 + USq6h35HyGJ8XrqWl4cb7 5qz 9.52 1 + uuB62majnBjKB9Lc4 uns 34.79 1 + uULdcnAIUFxDkF JI0 45.13 1 + uUp8nPNSheg2zdf4MsOsOShV dnd 92.51 1 + uvTCdgplgiN7Y1JysetLMFOd RRd 49.47 1 + uW0PG25fTkw9Rx7IMWAd e9H 37.66 1 + UXOFRISeI8Qf6rmd4PEP Fi2 50.24 1 + UY2TQLn18bcrKEs2 0ID 35.16 1 + uybUE5WkGAGis3iz8T7y uSw 98.98 1 + UYEAx0mOuNpQJGjZ rRR 99.73 1 + uYnJACueQS9AHYVaclwcC89s pPB 99.67 1 + v06hJC8wDms84e ZKo 35.55 1 + v1KMfS6cpybDLxhNptHl3g1 3c8 51.97 1 + v31Ksj4S3H5erUN VRU 54.72 1 + V6HurSZTOavkZ8pGs jLF 93.12 1 + v6WfOyQkIW49I8w6g vdS 63.82 1 + v7MX26rwq1wfTfU ynk 3.7 1 + va3JJjZBG5BkyBRl RVo 1.79 1 + va5tqd1huUVXAhstsQ MJ3 10.22 1 + vAVkAgxqXwDy5bwemAkeT 6F4 59.62 1 + VBbXpGZXGPu6RCbYACxMRLw nNm 83.92 1 + vbtwPamTB1bj8X HTp 14.61 1 + VC1G6LgLCKJLHjJ u5r 31.32 1 + VCeLkMbFThywPsi3u 4pD 22.76 1 + vDRO5wZLno5YpNuv ybr 77.91 1 + VFH6AH7wwjkCWZ OrT 35.34 1 + vGYHhVcP44YMXvl 1pP 28.51 1 + VHaBhBHq2MIiDnP PRW 26.72 1 + vhgoVjJUlBXDFdZCxzsaya5 byP 83.37 1 + ViIIoW5iw3jjYY 3cN 75.79 1 + ViUrMTJzbyMv5FEVZ4L2U 2Cu 53.13 1 + VJdxOa0cUOCdehC Cdi 76 1 + VjEGHq4Hfr4mpdH AYp 53.19 1 + vJKBFA2R0yKwcVYa6i6 KrM 30.69 1 + VjYMWDzBXY4EjDCe0X8LHTQ mbh 32.25 1 + VKIGIcNtliDEQTiT 60Y 46.27 1 + VKLBDIsd6zpZOu2 cHx 20.01 1 + VkwQveeFrNMvgeg0eLXhMw Av5 32.8 1 + vLIaSosKTKfP2x gq7 40.29 1 + vloWB3A3HY57KtTdbK rTo 19.64 1 + vltilX6riOX9kpMzBna7w2vr tqj 23.29 1 + VO0CHbaizesAMr5aVTFgwFR b0T 97.37 1 + vpchajIrSdh1S1 fA9 85.92 1 + vPlb1hBQU3px76vWSEm mHv 56.89 1 + vPQugjl2n6DAumhKfg 2nf 51.16 1 + VqwoQjSGqOHG5idIYuku4 WuE 97.07 1 + vROPqIOdNcQXlGu vw6 41.75 1 + VRzokuxwKlMt13 hHJ 90.36 1 + vSbUM9brN3tmHusQBk OQ7 60.58 1 + vsEtCGHKFooVluQFC qwa 42.88 1 + vtNClByfxwM1jcWmrZ i2K 89.11 1 + VUdyA2qWjBla2mcgbphX3b Acu 35.94 1 + VUncQYbai2j1TfQCCc7 f2V 25.05 1 + vV5NVSEt9iybQaQxI 82H 7.9 1 + VVM8O0ruc6ITW45Sl tLW 70.55 1 + VW5kltBFr8lPZ8JxIHIDTJS x2J 85.02 1 + Vwjufg3E9juTrQ FY9 32.49 1 + VWl8adVWg5LFq7 pK8 18.46 1 + vWqesjkTL758RF7KoOnRDKfr Zk5 39.25 1 + VwSTOQY3Nvwvwl7H K4B 62.65 1 + vWYJvMIPGkAHP60zlW nv3 85.84 1 + vxnh14t05Ho74Qm0dbs 2Ky 61.67 1 + vY72xMdYCe0iMsQi TVo 62.56 1 + VykD7LWaVxr5VyT 6Zl 82.57 1 + vyLJQ6WgvsD6XCqcpGW OLS 11.65 1 + VZaSPnxSH6mvOSuvJU 9gv 74.94 1 + w04nM63TBuTWx7OISI23zf 2M3 39.49 1 + w1WlXjmk4NIYWGxJbPJJK24 Rvs 69.54 1 + W2i1VIGm9riDFf kkO 80.31 1 + w4RHlt14C0ES7v qKq 27.72 1 + W6i2UCUaelSzr2lGL9Ts5 Rym 34.59 1 + w6WqmNGIeptTLbBpEUW0 2tZ 1.43 1 + W7PGy7dUw7CdNksU7Y6ITI6 k6F 27.58 1 + w95BTMeuzJYLF27VniD6BgB ZTQ 79.11 1 + WafiD0POjoXJJaHQ1VrXXNo4 EAV 28.19 1 + wAWdZR2piZxtJYmLeJu45X rIt 1.7 1 + WAWzxImFjBNhFgaq pgF 80.95 1 + wbC52JhiIbOCRaVYsEEhBsjC b0x 92.09 1 + WbyoPckqqS3vaaX988x lOT 22.94 1 + wCJO9G1gWMaw1NO Y02 14.36 1 + WcluqyDt8cxKZjfDWrSocMpm l32 84.96 1 + WDnV2Iw9s2U0hZB2yN9eeJLH MTS 87.02 1 + WdWGjEOPu4YJWtWfehMCW Jn1 14.49 1 + WEDI4uzoPrq4IeIkbjG8 l2b 75.18 1 + weIpCGsT1Vl0eWE zAr 40.43 1 + Wfp1En3Q4TWCgCEHwVp FcN 90.93 1 + wGFRDl88owz5S6qKsFfLN loj 66.7 1 + WGOgGNKUI9rJ8IOAjb6iQkc PUQ 7.53 1 + WHA8uuwDUng9XdNbl Sul 42.82 1 + wHG4PZVR76vx6uSI jfl 5.54 1 + WhlA1GNEHgmUvLJC2 Rs3 2.85 1 + wiAPnE21zfHA6Z88E20V0 Z9t 27.52 1 + wIaqUBG25Yzbu7ZxR c0J 16.07 1 + WidngrZLXel7yzSF73HV9 wYg 40.18 1 + WIH3SOeP0yXH5nEK0qXoLH Eok 86.04 1 + WkBN9x4LI7V7PnjMkEg 147 15.29 1 + WLfo94mpw1o8Kbf2a a6z 92.23 1 + WNDES0MdgiRR8jj AYQ 89.86 1 + wnLYCRGWqEd0CYuUQugaJJb qsR 83.91 1 + wnp6dLsieyRtDQlegF 4L7 34.7 1 + WNU6OrQQ3HKAyoQ8c7 OHM 95.79 1 + WO8wMOEq5E7AAbVrAaAS 5zj 73.13 1 + wp6OZ2Tz2P63ImEF Cv8 43.25 1 + wqSXAkIu6hm6wOB9MypS mvz 53.39 1 + wrYaCoZvq382kidwns Dr8 84.59 1 + WS4CBFMmzH7zafR6 Vht 35.13 1 + Wsd9WNkUS6en4KJOB7VUY bHF 34.7 1 + wsSCg4pxP4GnKIQQKR xiV 38.4 1 + wTqYkZ3tbjLUfofA OZf 80.25 1 + wu0eZF1g4Vy5j1F gb3 30.25 1 + wuhoaNNXiUcmQu8MfvkZpj HFS 20.94 1 + wuqKHVboW6oAsnd59xKtp sG5 8.59 1 + wUsOMxLu5uapAopQkE Uiy 3.38 1 + WW0y8QypoznWVc8 1Uj 63.23 1 + WXc918pVzGQoQskWnvnNI78 ocZ 57.05 1 + WY4aAXv8f9iPwqnMSn5bd1 WNG 74.13 1 + X0ci0dQ6Clz1dOBXO6hYN SH0 72.11 1 + x0lK3HF94lK99GWIKXw7avy Yq4 78.01 1 + X1g0Fa783sy2IM2Pc11VHqtr l9G 6.72 1 + X2A04y7BlJWKwj8af3ftIK Pj3 15.34 1 + X2HeRVwr3HwW5UgUoPq cNS 68.33 1 + X31i6o8dCAEbb7 UjP 44.5 1 + X38PxEKWnWnZjzWA hk2 45.21 1 + X3PcRo3W4Gcj3YxMV Jko 40.31 1 + X7JROHrCbnFu4nz9L jrT 88.53 1 + x7yR4WekD59VLb dHm 13.13 1 + xA3ZZPZGPZz4CpmIZb2pY4 iBd 93.5 1 + xAAbqdhFMj6rSoxEeXFxayWG 1Ea 90.9 1 + XaP4K9Cx3QFqI2 wLF 50.35 1 + xavgftQfXQ2FZL1PQtpo DRX 5.93 1 + Xb8Uqy3Vgr2jX2XtzBC WMr 70.1 1 + Xba6Npti5yIfU6qq6Uh4R huM 91.89 1 + XbKQMytue5lnPkVZSMUmby EWb 42.3 1 + xcjnBI7rtrPAT2nE uEX 41.79 1 + XcxPdaojEtO4iUldHI nEu 41.19 1 + XdBIsMbPUePSW3Mm6KcYIuR ryW 81.88 1 + xetPAvJWrG2DGibcgI IBH 29.69 1 + XfyfNBWIKmqgwRceqge8zeXa ODK 24.63 1 + xGC0PGdvKZB4eUcFBXmo ghE 52.33 1 + XGch0a918Bi8gsb DvS 89.26 1 + xGwqgX1dUF9upg31 JPk 90.06 1 + xgZtZKhbcoWThEw5wGB RbE 24.88 1 + xIx1Qj1OVMQcbT1 0DR 42.71 1 + xjMmd163QZIDupNo Yth 56.1 1 + xjuf1THNUvBJ626XGBc1 Sg8 92.39 1 + XKDErHPffv2LIbu e8Z 99.38 1 + XKem1DpBqcsaucbQq7f olm 30.02 1 + XktieuBbkiTVv0kTwrmRTz aSA 87.21 1 + XleZC1OP4pKtsqFfyWH09SWZ rAF 33.88 1 + XM3GerTLovpOmIsjXqcyu ksk 35.99 1 + xmRyNN5aCowYqCef 7NC 96.55 1 + xmtGtFPXUDZX9d2TMarr9Fs Vor 89.33 1 + XN2bCEAUhcw5rNIG8LR6 IXH 45.78 1 + XNpnuJkXkBLHYS6 AyW 60.53 1 + XOBZeRVF7tkf5gPfBFWGkqL lEI 32.94 1 + XoEdUNaVJbjkFdT37bsY aBz 20.88 1 + xpERJlyvsUZItE04J1Ifl zSF 61.67 1 + xQVPiCddOZqGJuFBB Loc 30.13 1 + XSCZ2etE3GPKilgp TWd 20.62 1 + xt2xS7RTO3djz9B1dsLt55cu hPf 41.6 1 + XtcVi02GCdnEZwIh bgp 92.34 1 + XvSxvehW2SpKSb Z5D 90.41 1 + XWFpRaXkRxxdL603p cRh 45.14 1 + xWLVk81UzxCLYHDTkL 2vd 90.35 1 + XwrW7vufh20Sl320nSSAklAt piA 39.67 1 + XZmUOY21cmp6Rh E2X 52.91 1 + Y0rUgo7FlunHOrgdwYEYC MzD 27.5 1 + y0ztVqQkc9RISpY uef 51.97 1 + y1nNGFSAwyHreeOjIj ltB 5.36 1 + Y6jvY7foR7Sl3bzeyJjhAD4 aXY 14 1 + Y7RL4OgHy4aRuV2stl PaK 65.67 1 + Y8TnSiabnr1jbri lp1 76.12 1 + YAIMMo7Lvqjkgp1 uO9 77.92 1 + YaXjagdzO77uUVAoN8Ozs bNm 38.07 1 + ybDJ3X8oUNt3U4bf OQq 4.21 1 + YbKWuFJL6pMMKh5lkwXhC OTO 19.11 1 + yBsTxoMOSuL2OQ6KMEPM6cLK TyT 6.22 1 + yCQo33cLmsgVVxx m6t 25.59 1 + yCwguRlWVZMAIfHgUmaVt cyz 67.13 1 + YddOe7TTfksgIwowK jMY 34.06 1 + YDe10m758fsuaTG1 oUM 78.1 1 + yDnENznEnLVzCGuoCOBHQG zWy 81.52 1 + ydqWU0Zcxp52Cvl fOF 43.42 1 + YE6D4n4J7ajBLQyp0eA 211 24.51 1 + YEKkcr4tQDDK9nobDwz 749 1.09 1 + Yf1ei6thDJWBkai2E09nl tR3 45.68 1 + YffrvumTPlZqR1kTRSm sdV 10.91 1 + yGIKSz03msfYEVQI2qKIsj kHY 50.91 1 + YIJCQvkB9WHJ4DiAfPmkF 7nR 35.26 1 + yJqU1OETNzihkL qtD 44.5 1 + Yk08TfZs5CcKjI9tGyl2RsYL qRQ 63.08 1 + yMnutEiPxpbXt1GnoFGd3G3 L8B 58.22 1 + YNnm5QEQ0nbjpu aBs 41.71 1 + YoAWyfqDO2zlfNM9fRDg 4L0 61.78 1 + YORinqwGkNuvvMcHy9XuE V4N 3.1 1 + YpgR0uHiJE80VbS hGy 84.21 1 + ypUZzU8lhQP1n3xYR1NIb Kyu 28.1 1 + YRYovyciDIWo2WKzr RgE 27.39 1 + YstdxK2JW8ZzU39hm BVP 3.83 1 + yTa6a8QRg8ErVXd1B8 AgK 36.93 1 + YTJkVAj41wIrXL9SD1S1K P3r 17.34 1 + yU0rQeGImscj8aaVrHmJ5 VWP 5.68 1 + yuYQXEuOB5Xl2HnsqMiWlZxB LJV 87.42 1 + YVMIpkAZkAuwhenXwqvzJ xdl 17.21 1 + yvpKM5VDTQ80aN7rZncvZM c0X 78.57 1 + ywbfIhFx8pBVpRXty vHh 29.87 1 + yX6T4dG06qhQZ6Otyjb 6Nc 14.11 1 + YXouwXXX8eEVI7 rOG 35.07 1 + yztTo8pZgplkub6M Na9 37.86 1 + Z0BRxLp0y6yUPtwD9U 5JQ 72.53 1 + Z0i4ZuioNIyn4VP6 EST 75.28 1 + z2axjEQyGHLyCNMi9aF2TMlA TRx 56.45 1 + z3CNwWMBczlLeLQTXrYhxhHF 6tB 38.29 1 + z3cSvDFe3sMKsHyfWCRZdXQ Cor 71.94 1 + Z48sH6I08VcP1oGRtzfq8CfJ 6P5 39.85 1 + z4Kt5fRtrD2I4Jun0idlD7s Od7 80.61 1 + z4LNvVvPttwYhL caS 81.03 1 + z6CpY3vGToEeFoGFvVoX5L RHm 91.19 1 + Z7HJoJWePs9DfL wMb 39.24 1 + Z9W0VIzTcJlyBt8n 2vi 22.7 1 + zBm65MU6sxXieUOllu WZN 86.21 1 + ZbNlY0mTCxv3NmWfmA8DaQ PBO 88.88 1 + zbNu1xxEjde6HW C5d 77.68 1 + ZBwv0nClcq6fF0sdiMcj fKO 42.58 1 + zd84PS7RDAWhYJ BaV 20.37 1 + zDhfnfp94ZBkpL qbe 16.66 1 + zDWUNTGRNSVHDtC34oEZ4E 3du 86.19 1 + ZF2AyMtnkYRKQHm7PZxlv BxP 91.31 1 + zf2p9ajWtGH29kZYoWdGrU j3s 9.26 1 + ZFJcROx8weBQE8ogoQM rC9 2.25 1 + ZFRvIQM6XjfVWh see 26.47 1 + Zfyuiw5jrlT84oEtr MHJ 18.46 1 + zg8ggpg3qkR0RmfHa kg6 9.34 1 + Zk8hs8cvh7FKmO l8b 68.11 1 + Zld8Q5yRf6eiE2UNtz9QK E7N 56.79 1 + ZLtdlrUys92fuSccJYPmx9 Bum 97.42 1 + ZMxJHnz4An7m4C3LDf3Af8AQ auG 20.17 1 + ZnpzeNsyeJXAFZRdDagu P5Y 81.42 1 + zNRXf8lbdh1mSGU9mV4L Qty 18.76 1 + zOGsAMgiUpRD1lCUb34ATM dnJ 7.53 1 + ZoX5p0L1uKfHlS5zcCBIj 5eO 49 1 + zpokwAZYw1YQkw2 VvO 55.16 1 + zq46tAk9DESTglVxmU 0kA 89.53 1 + zQd0y5Nz7NkI4bCxbxkM9 TSW 75.19 1 + ZqpxhD6b9RDKMD2EOx 2nd 3.87 1 + ZRd0N7ngdjsghO8qP 7UJ 24.98 1 + zrfVBd1A6T23x5PhAv pZt 61.89 1 + zROImS2r0gmZPHu2 C2U 70.08 1 + ZtBZmK0TesJqpbPgG SHo 71.26 1 + zTjEQkKztB9qh57r MpR 45.86 1 + zUG8qz5tVC5vTWgup uRL 96.19 1 + ZUxpDw11omdd7J78WVm Omh 62.06 1 + zXcDPC1sQRwiXKICxW MMN 25.92 1 + zXHVES5b2EC0vsIItf NeC 17.83 1 + zxMHyXniVBNuJHq1qBSv OYJ 50.15 1 + ZxVaMV55c2scJStgn8 M3o 87.5 1 + zY76m194yqaEKSZ027ZiaHfL CI8 61.72 1 + zyBFm2DG74zK26LL6Ga CNK 59.42 1 + ZybIvbbugXyNBR Zqf 40.42 1 + ZyBzM3RXghCJe8wPbxO6Dj 54N 32.44 1 + zynrGW9lxFY417 vGS 76.27 1 + zz3rluGqjB9PkRZdk8aLo 8KV 97.04 1 + ZzMdffMv8f54bHMk3EX RTO 94.7 1 diff --git a/e2e_test/ch-benchmark/q17.slt.part b/e2e_test/ch-benchmark/q17.slt.part new file mode 100644 index 0000000000000..5903ccdb17b7e --- /dev/null +++ b/e2e_test/ch-benchmark/q17.slt.part @@ -0,0 +1,11 @@ +query R rowsort +select sum(ol_amount) / 2.0 as avg_yearly +from orderline, (select i_id, avg(ol_quantity) as a + from item, orderline + where i_data like '%b' + and ol_i_id = i_id + group by i_id) t +where ol_i_id = t.i_id + and ol_quantity < t.a; +---- +7032 diff --git a/e2e_test/ch-benchmark/q18.slt.part b/e2e_test/ch-benchmark/q18.slt.part new file mode 100644 index 0000000000000..5b58a42a546b5 --- /dev/null +++ b/e2e_test/ch-benchmark/q18.slt.part @@ -0,0 +1,37 @@ +query TIITIR rowsort +select c_last, c_id o_id, o_entry_d, o_ol_cnt, sum(ol_amount) +from customer, orders, orderline +where c_id = o_c_id + and c_w_id = o_w_id + and c_d_id = o_d_id + and ol_w_id = o_w_id + and ol_d_id = o_d_id + and ol_o_id = o_id +group by o_id, o_w_id, o_d_id, c_id, c_last, o_entry_d, o_ol_cnt +having sum(ol_amount) > 200 +order by sum(ol_amount) desc, o_entry_d; +---- + BARBAREING 10 2015-11-22 00:00:00 5 8745 + BARBAREING 10 2015-11-22 00:00:00 6 4321 + BARBARBAR 1 2022-10-11 18:09:03.084829 10 2204.5 + BARBAROUGHT 2 2022-10-11 18:09:03.108880 10 2204.5 + BARBARABLE 3 2022-10-11 18:09:03.133535 10 2204.5 + BARBARPRI 4 2022-10-11 18:09:03.156298 10 2204.5 + BARBARPRES 5 2022-10-11 18:09:03.179062 10 2204.5 + BARBARESE 6 2022-10-11 18:09:03.204205 10 2204.5 + BARBARANTI 7 2022-10-11 18:09:03.226772 10 2204.5 + BARBARCALLY 8 2022-10-11 18:09:03.250607 10 2204.5 + BARBARATION 9 2022-10-11 18:09:03.330918 10 2204.5 + BARBAREING 10 2022-10-11 18:09:03.358011 10 2204.5 + BARBARBAR 1 2022-10-11 18:09:03.381578 10 1235.19 + BARBAROUGHT 2 2022-10-11 18:09:03.403741 10 1235.19 + BARBARABLE 3 2022-10-11 18:09:03.426918 10 1235.19 + BARBARPRI 4 2022-10-11 18:09:03.449726 10 1235.19 + BARBARPRES 5 2022-10-11 18:09:03.471114 10 1235.19 + BARBARESE 6 2022-10-11 18:09:03.495396 10 1235.19 + BARBARANTI 7 2022-10-11 18:09:03.515557 10 1235.19 + BARBARCALLY 8 2022-10-11 18:09:03.534517 10 1235.19 + BARBARATION 9 2022-10-11 18:09:03.552724 10 1235.19 + BARBAREING 10 2022-10-11 18:09:03.570662 10 1235.19 + BARBARATION 9 2015-11-22 00:00:00 6 998 + BARBARCALLY 8 2015-11-22 00:00:00 5 543 diff --git a/e2e_test/ch-benchmark/q20.slt.part b/e2e_test/ch-benchmark/q20.slt.part new file mode 100644 index 0000000000000..cc37b7d2cfa07 --- /dev/null +++ b/e2e_test/ch-benchmark/q20.slt.part @@ -0,0 +1,19 @@ +query TT rowsort +select s_name, s_address +from supplier, nation +where s_suppkey in + (select (st_i_id * st_w_id) % 10000 + from stock, orderline + where st_i_id in + (select i_id + from item + where i_data like 'co%') + and ol_i_id=st_i_id + and ol_delivery_d > '2010-05-23 12:00:00' + group by st_i_id, st_w_id, st_quantity + having 2*st_quantity > sum(ol_quantity)) + and s_nationkey = n_nationkey + and n_name = 'GERMANY' +order by s_name; +---- +Supplier#000000011 JfwTs,LZrV, M,9C diff --git a/e2e_test/ch-benchmark/q21.slt.part b/e2e_test/ch-benchmark/q21.slt.part new file mode 100644 index 0000000000000..d75d7cba2e11b --- /dev/null +++ b/e2e_test/ch-benchmark/q21.slt.part @@ -0,0 +1,22 @@ +query TT rowsort +select s_name, count(*) as numwait +from supplier, orderline l1, orders, stock, nation +where ol_o_id = o_id + and ol_w_id = o_w_id + and ol_d_id = o_d_id + and ol_w_id = st_w_id + and ol_i_id = st_i_id + and (st_w_id * st_i_id) % 10000 = s_suppkey + and l1.ol_delivery_d > o_entry_d + and not exists (select * + from orderline l2 + where l2.ol_o_id = l1.ol_o_id + and l2.ol_w_id = l1.ol_w_id + and l2.ol_d_id = l1.ol_d_id + and l2.ol_delivery_d > l1.ol_delivery_d) + and s_nationkey = n_nationkey + and n_name = 'GERMANY' +group by s_name +order by numwait desc, s_name; +---- +Supplier#000000011 10 diff --git a/e2e_test/ch-benchmark/q22.slt.part b/e2e_test/ch-benchmark/q22.slt.part new file mode 100644 index 0000000000000..70f6e5cf7ae4f --- /dev/null +++ b/e2e_test/ch-benchmark/q22.slt.part @@ -0,0 +1,21 @@ +query TIR rowsort +select substr(c_state,1,1) as country, + count(*) as numcust, + sum(c_balance) as totacctbal +from customer +where substr(c_phone,1,1) in ('1','2','3','4','5','6','7') + and c_balance > (select avg(c_BALANCE) + from customer + where c_balance > 0.00 + and substr(c_phone,1,1) in ('1','2','3','4','5','6','7')) + and not exists (select * + from orders + where o_c_id = c_id + and o_w_id = c_w_id + and o_d_id = c_d_id) +group by substr(c_state,1,1) +order by substr(c_state,1,1); +---- +g 1 1000 +i 1 1000 +y 1 1000 diff --git a/e2e_test/tpch/insert_supplier.slt.part b/e2e_test/tpch/insert_supplier.slt.part index 2946bb438901d..d367b29a4f2a7 100644 --- a/e2e_test/tpch/insert_supplier.slt.part +++ b/e2e_test/tpch/insert_supplier.slt.part @@ -9,4 +9,16 @@ INSERT INTO supplier (s_suppkey, s_name, s_address, s_nationkey, s_phone, s_acct (7,'Supplier#000000007','s,4TicNGB4uO6PaSqNBUq',23,'33-990-965-2201',6820.35,'s unwind silently furiously regular courts. final requests are deposits. requests wake quietly blit'), (8,'Supplier#000000008','9Sq4bBH2FQEmaFOocY45sRTxo6yuoG',17,'27-498-742-3860',7627.85,'al pinto beans. asymptotes haggl'), (9,'Supplier#000000009','1KhUgZegwM3ua7dsYmekYBsK',10,'20-403-398-8662',5302.37,'s. unusual, even requests along the furiously regular pac'), -(10,'Supplier#000000010','Saygah3gYWMp72i PY',24,'34-852-489-8585',3891.91,'ing waters. regular requests ar'); +(10,'Supplier#000000010','Saygah3gYWMp72i PY',24,'34-852-489-8585',3891.91,'ing waters. regular requests ar'), +(11,'Supplier#000000011','JfwTs,LZrV, M,9C',7,'28-613-996-1505',3393.08,'y ironic packages. slyly ironic accounts affix furiously; ironically unusual excuses across the flu'), +(12,'Supplier#000000012','aLIW q0HYd',8,'18-179-925-7181',1432.69,'al packages nag alongside of the bold instructions. express, daring accounts'), +(13,'Supplier#000000013','HK71HQyWoqRWOX8GI FpgAifW,2PoH',3,'13-727-620-7813',9107.22,'requests engage regularly instructions. furiously special requests ar'), +(14,'Supplier#000000014','EXsnO5pTNj4iZRm',15,'25-656-247-5058',9189.82,'l accounts boost. fluffily bold warhorses wake'), +(15,'Supplier#000000015','olXVbNBfVzRqgokr1T,Ie',8,'18-453-357-6394',308.56,'across the furiously regular platelets wake even deposits. quickly express she'), +(16,'Supplier#000000016','YjP5C55zHDXL7LalK27zfQnwejdpin4AMpvh',22,'32-822-502-4215',2972.26,'ously express ideas haggle quickly dugouts? fu'), +(17,'Supplier#000000017','c2d,ESHRSkK3WYnxpgw6aOqN0q',19,'29-601-884-9219',1687.81,'eep against the furiously bold ideas. fluffily bold packa'), +(18,'Supplier#000000018','PGGVE5PWAMwKDZw',16,'26-729-551-1115',7040.82,'accounts snooze slyly furiously bold'), +(19,'Supplier#000000019','edZT3es,nBFD8lBXTGeTl',24,'34-278-310-2731',6150.38,'refully final foxes across the dogged theodolites sleep slyly abou'), +(20,'Supplier#000000020','iybAE,RmTymrZVYaFZva2SH,j',3,'13-715-945-6730',530.82,'n, ironic ideas would nag blithely about the slyly regular accounts. silent, expr'), +(21,'Supplier#000000021','81CavellcrJ0PQ3CPBID0Z0JwyJm0ka5igEs',2,'12-253-590-5816',9365.80,'d. instructions integrate sometimes slyly pending instructions. accounts nag among the'), +(22,'Supplier#000000022','okiiQFk 8lm6EVX6Q0,bEcO',4,'14-144-830-2814',-966.20,'ironically among the deposits. closely expre'); diff --git a/scripts/source/test_data/tpcc_customer.1 b/scripts/source/test_data/customer.1 similarity index 54% rename from scripts/source/test_data/tpcc_customer.1 rename to scripts/source/test_data/customer.1 index f34189a7d76c6..7db25786a31c4 100644 --- a/scripts/source/test_data/tpcc_customer.1 +++ b/scripts/source/test_data/customer.1 @@ -1,105 +1,170 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":1,"c_w_id":1,"c_first":"2 4Py0Rg","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"PwR0ymwiRN0m2","c_street_2":"B60g4NwRNw6kLy","c_city":"04y2 miNRw0y4Nki","c_state":"22","c_zip":"093011111","c_phone":"490-950-6869","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3173,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6ymmkmwyLPiN66RRyggLy m4gm6N0g0wRBwiw4NwNywN RP66yPiiLi4P6B46BB2m giLw4gB22w6PmLkLyRkk0N0mikNmg0m6Ly4mgN0P2NkgPy wwNmkkLP6g6y LPBB4P2giiw4immRikNR6w0LLRm0NwP6NP6i6gy4i0P4wB6P4By PmiiPNBL0y0 L R220Bykg2 N4wL iwm66Ng4g2yR6iy02LyBy6Ng22RwRyP L0iLmwwkL","c_data2":"LPyPmg2gwg Ri4ikBB4B242LBmL2RP4BRg6i6BkkR L4 0B6Pw0R6BBP04m0ig4k6yBkLyL 2PNy immkNiwRm4Ry4m6B y2R2gLmmBi wNLwi6Pi0RkR00wg 6yk40N20PB R4iiwBkw4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081149,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081151,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":2,"c_w_id":1,"c_first":"2RiLNwkk0","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"iL04 gL6NP2k","c_street_2":"02RL0RwkRwi46giLw","c_city":"mNkPPyBymii","c_state":"6B","c_zip":"927511111","c_phone":"208-324-6621","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2Bim6PPL 2P6iLi6 NigB 6wymBR0mP gN4kiggNPNLgyi22wR644BB6PyBNL Pi0wPiRLRiwRw6 yw0B Bki0NNg06iRwyBwg6NgR 4iR64y46Ly4wgR20gw2RNw PNL2yk42w 440P 0 Bgi2Ng ky4BB62g 0Ri4BiB2 46kN0kiLP0iiy0BPB20R66R6yN62LwBR0yNiL6yB04gPgRPPiBRw BiiN2 kRg2RikLigm6wL2g4PmB2L","c_data2":"6Pg4wRkmPR06NB0iRw60LmN6 0 gLm2 22mB wBPNmk0ygRw00NR4yw2gwNyBgLLP mRRBP20PByk4ywBP0RP6g24ki m20ikigi2NNL2P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081154,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081154,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081154,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081154,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":4,"c_w_id":1,"c_first":"gg4P6N RNLw kw k","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"kB4gg6 N2iN","c_street_2":"P24yBBgyNim","c_city":"Bi22y22wkBB","c_state":"wg","c_zip":"434611111","c_phone":"708-713-2028","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2625,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gBmwyiB226kw4PP 4Lk2L2Big64kg2 R402w2i4yBggPLg0wP4wm4yR6RRk6mwm64iyBBBg2kmyLyL4RRBLkiNRy4yPPw6 4ikk2wm60 4RNBLP4R mm44L0w6N 4g kymB6gB RBLLk6gNP6 wmPiN4gkN6N22LyNmRwR2N6Pw64wi4igwmiRN402yR0RNkBiRN0kk mm6ggiRimmk6w206RikyygL4m6 Rk0P4L226PNiwk4 mkP2062","c_data2":"g2PLwB mLN24NgLN0RmgNky4RNLNyBkk ywPPm N0wNN2wBNgmP26km20 L4ggmLgmN4R66RB40gLyBRyP2m46B2gi4mBRwB2 BPkNLm4N PNPy4g4i6N4g20PLm2LNwwwmR6 mL0w22LwBNB64mL0y4w0iB4066Rgi g kg2 g00kNg02giP6wN6 4igiLmwk44PB6NPR6iPRBBRR4kiyN6NPy6g2BPy y0N4R62y0m2BiL6L4y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081155,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081155,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":5,"c_w_id":1,"c_first":"2i k 4gN2k B0","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"gN2gPiwgyk","c_street_2":"m0w2P4y0mgPw64","c_city":"wykB 0kgw","c_state":"Ry","c_zip":"628911111","c_phone":"139-894-5975","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4989,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R RwP 2wk6mN0i6wiNR24yRRP LPkmm42k0iLNR62mNRi 4BNRyR4NkPPgm2yL20y4gigkk2020L24Rmkig2L2NLky242L4ywPiwk 66k0g4wBmyPkRPmBg gi2k64g40m2Bgw6gwL 0kRkBByP2gm N42L0wB 6ykkmi2PNR0R6 B2B4PRBmL2w0RgwgmLyk2w gRyL PNLw4m64 kRmm2NPNNLNg w4w0ykBRkkk0Liigkw2mmR4miyw","c_data2":"wgNm4Pmmy6iP0L6mykmm wNRLiiR2gL0NyNPL62B 0w4my4 PN6gBwkm42Rg6RkNk4m LR mwg4B6mki6Pmg42P40Li4L4LmkN22NBNRPkBgLN mk0 60 N4ywR4N04my0PBwkLiBwwgL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081155,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081155,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":6,"c_w_id":1,"c_first":"P4PB2kyy","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"4wi B26Nk4L2","c_street_2":"PPBkwgBiPLBLRyB6mPB","c_city":"PgmRgmgB4P20","c_state":"ki","c_zip":"465111111","c_phone":"220-874-4078","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4935,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"44k2wm RykgRmk 0y w4Ry6w4N2BmB6gwk 04BBiL2LgBLimkmm0gk0yy2RL2y2N iBLPRNii2PN242LBiiL0L0B64NBwN yBL6 gm6ByBN2gNimm2ygBikm wy4P6yk RP0wBBgg6B4iLLLi2PmRyPwR m4mBykw4NBg6B6yL6N2BBkBR0LkBBwgN 20wBi2gyP4k0kgy P4PmB40g0B 2LwLBgBR4kN 6B2RwL4ykg6 4wP4NRwgy0gN","c_data2":"ymBm4 wwP y4BLRN0 i m 2 mRLiyLR42 0Pk6Pgk64wmggRN446kB4BRR wPwkgyPi N4yN2NkR2L44P 2m 6462yw mNRgPyw mk6y40Pykk2wimyLyN00Bw0wigL R0Lkk2w06B mwN40ww20BBR 4wRk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081155,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081155,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":7,"c_w_id":1,"c_first":"2BB0BB6LN2k","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"N42gLmkLBPg","c_street_2":"60myPRRgig4N 0 2w","c_city":"LN y4RPw4Ly 6w","c_state":"Lw","c_zip":"956311111","c_phone":"799-822-1590","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3341,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LmRigwwBy2ig24 RgiLNm26026mPB64wL0Lm P06w6gg w4N0wBB0g00B4Li2iky2wLL NB 4Lmmy46g 00PmRNygg4iwNkBkR4g6y22Rg4062iwRi4wLygNPNBBwPPgy24 y6kyyg006LPw0R 0L4L2BL42046L0BRg2wRgy4imNRLRkNB6N2wgNkyB0m22wiPNPkg2wk66g2PR kgymP2BwiB06mkg2 NkPkiRBy2imy4PRgNkB4440P","c_data2":"RR6RRyi6yi6LP mmmL222kg46iBg46k0N0B66g2gRRBgy6iNB6RN2m6kkikRmBLkygNkN0g0 4404iP6w2B2B2wkBi66L 6R62NPNyiwkwRBkg02 NBB2B2wm0Ly422gm0gmL0i4myg02B2k4mw0y0Ny0B6 kRy mBigg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081156,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":8,"c_w_id":1,"c_first":"400N 6gBR0yNkR4","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"gkyg4w wBmymNPi","c_street_2":"gk0LwBg0kP4NBNPm","c_city":"6kyP2iB Rym0kmPN 2","c_state":"mi","c_zip":"709911111","c_phone":"868-574-3700","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0829,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"y P N64BkkkBkm N kmi0 LLy wiN4imm64PgPm0Lg2mwP4m4LRy4wwgP6624NPky0wm4 wgkmgBy2g LLNRmB0wgRLyLB00w4Lkkk6w2mNkkP40mw6NLg400iNywwL ki4LNky0gi464yNg2imy4ygwkgPi6m0 6y6B0ikNRmLmmw6w 62wgi 064Rwgw4myNLygNRLBB 0 mN6B0LmBRk6PLN622iy6BwPLgL6kwPLPRiL mkm RwR","c_data2":"B Pwm4mPRLi2N6 BP6R iy4P iNmwi0BNLgRPLgw40LiwymL0mmBRkw0RBBw406i6BgR4i iw0kN4ky4Lyy00yyB66g0iyLiLPmgy6gRRiBP44 wNRwP24Lm6kiyP6NBLBkkB4P2 6my 60kmRB6L iLgyw0Rwmiww26NyNRB0 4iL0w00NL iBik2yL0ym6B0PBLymgN02BN4L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081156,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":9,"c_w_id":1,"c_first":"R0yiRik kwP24","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"N40BiR 0 0kBygkPBm","c_street_2":"kLk2LmB yBkP","c_city":"mRRPPR4 k2L","c_state":"6L","c_zip":"497811111","c_phone":"552-389-2881","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4114,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6RLy44yLL2kPwkLy2gymRLyPkmgw202B6w042R440 yR6yLmiPw6yi4iBNmm2gg4i0iiBR2wi2gy462wN0gBwwiy my20gL0Rw4RykL02g2 kNRm4y6PNigmy6gg226Lwi4iyyN0PP44m060PPPRL2Ri0Ni yiRN266 2RkmkmBN2 4RkykP4gRkBwNRRiyP gBiw6y6k0wNRg2RNBB i Nw0B0Li iLRPyPyy0R0kBwPyLk4 i44R62yw","c_data2":"N4R0wLNk miiB0N2giN6mB2gNyRLNL2LBBBN2B20NBB6iyk m4mm6PNgNN4 226kwN6gy0y NLLwR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081156,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":10,"c_w_id":1,"c_first":"wPmBgmgNiP0 64B","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"wNNmkkB0Lw","c_street_2":"gPRwyk4Nmm62i","c_city":"2RLPNg24i204 2","c_state":"0P","c_zip":"663311111","c_phone":"116-402-5438","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0339,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NNmPNPiywwBiiw60LwL4yRmP4gwiwLL4w4NP 2 NyggRkwikBN k wRkiPB0iNmwR4L mRk0w6w4kPRm4wm2i00w00m40N02kwgLLwRLwi2BkNyB0L20g0y2LmgB0i4yywL0 BL Lmi6k 6mm4g 2y 6RRww6mRi2kBm2g NkBN4 22 wPkmymigwymLPkwm6PNwwm26N46L46gmmyyBLkmLkLyLN2BiRRi0L4R2ywNmkNNLi4B26k2N0m","c_data2":"gLLyykmw2LkNPPkN44gkwwP NL42P6mw0BR2PNgyPRi2060P0PPNR 2iyL2i0mRN24kmiNm420kkyPNw4Rmmm2kgwyw46gwwik2gymLmLwgk0R0ig6L4N www 6L2wNBBB0gBigB BN BBL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081156,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":1,"c_w_id":1,"c_first":"gP22PmwB2mgkBBw","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"gygPLL6BkBPNm0y","c_street_2":"LLm2 2RByRRmRyy4","c_city":"Bw4Lkm404k2L","c_state":"NL","c_zip":"610411111","c_phone":"548-579-5258","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2789,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LgB RL6g0yNRmLw Rkwi NLPgmmk 62 mwygLg4yNNiNL N4Lyi00RkB0yg44ygmL0Lk4 R44myikNBw yRg mgk PBi2604mg2kL6gymgwBNkB w LwkN0wy0my0L20 B64yikLkL yy0PL4i4P0RwiBi y4Rggkww6i00y2yLR2mNBP6yk P w0B4 PyB L6 N42gR2RNiyiyL 6wwgNymBiyik2P Lkig 6k4wk04R0Nm0iLy6m04","c_data2":"gk4 iyR4wyN0L k2NmP 4L0mN0LP0N4gwB4PLNP04wRNkL400Bykky4 6g6gNw26R4PNw6N4iw6RigyBB4 R mwNw k0m2PNkLRyNw4 Ng0NPR62yBL42RBNLy0L40 g gyBii6RR4igRBw6gB6BLy4 2N0wiy4kPi2w0gLLNwkR20L y0wkkwy62imR2iik066 LNy R06mLNPyRRwkNyigmByLLLPmRPgL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081157,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":2,"c_w_id":1,"c_first":"LmgLmgw0i0 L0R0k","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"L4iyRymNwNPm2","c_street_2":"0RNBy4yBk 6LL0i6g y","c_city":"gR60mmLNR22NLLw","c_state":"km","c_zip":"127611111","c_phone":"706-741-9824","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.117,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"km0wBk6RRim4yPwPg0m6PRkRP4myLgkRB4i0 g6 yRi2BiN2i gL02kykLigiimRyP 6LB44wBRmBw2Pm 6224Rw4mLBikNP k26PiPN6wRNwRywByP0iBi22ikPwyiP602mLN00i66 PNBikB2 NN4w0PB0iBwLLRBwmikyP0NNy wB 4Bkw4mBykLg 440wgPi024006ymkyRByyLLiimyi6PmNiigNm04i246RNk gLPNNBi46B2P","c_data2":"BwB0LRwm4 yPimg 6kN2 i w2B k6R0 im6iNL6R0iwymyP4 RyLmiLNB4Pi6L4kwiPmwNgwm2i6m40RLi4i4BkRykywm2mmiwwLRmB4Ng0gPkwgLk0 0w0mB4wm km2mN2Rg2L B6646kN2RPBwg4m4N6B i yigRPw2Liw2gB4 L m4ygk B P4BPiy06y02LgB4kBRk04LN4N4gyR4wRP62RRR Pky0m2gyykmm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081157,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081157,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":4,"c_w_id":1,"c_first":"LBg6 RPggB","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"Bi2 2kRgk","c_street_2":"i g0Ri 4PPym","c_city":"yN0kRRyki0R4B","c_state":"w0","c_zip":"457411111","c_phone":"281-912-6413","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0899,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g00m0Nw6RygRyw0RB4kyB4BNkiLwkBP404R6m0NB 46B6B0wi6Bk4BNNmLL2w4mywPw4BRkByBiBB46Nwk4wgkmP6yNm6wyLNyLmi2wwwBRR2yLB4m0NLNN0 m m0i2y6 g NL 6yi2 N0R0yN0N66PmPg0L2iP4N4 i m4w6mB02kNiPNBLm B46BiPkP2 m60y0N6Py4k44m6L0i202RNmLRN P22B04PmmiPkwiBmkNPNNmBRR w0","c_data2":"R6PB2gN BiPNmi04wgN060N2 LPiRPwL4iPPy Rmim6g2 6gk2i60LLPi6yk 0R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081158,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":5,"c_w_id":1,"c_first":"Ny 00LPiy6R4RiP2","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"y BkNwRiL6w4y44y26","c_street_2":"gLy6P00 yyyRL","c_city":"L2wP2kPPR 2w6N B","c_state":"m","c_zip":"613111111","c_phone":"555-982-5116","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.198,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"y 2k6kBky0RL0666RgRNN04BkgB0wNi4wR 46kk0ymyk2mm6BmykBB2i wBB4mN4yPykBiikNP kgBPiNLPw24B0NLB46iggwiLg244ikBNRLmigw4LRN gNykPyyPBiwLByg46N4yP mP2RmNBR4B6yNywk0R By0PBPRy0B0P kgmB62 40ymyPB 6L6RNkPBwP64k g0N0Bmm60gmyRRB yNimLPky6g RyN4NwB0yBkNg240mLgw2B","c_data2":"mLgRmR2R2Lw2RmRP2k0yLgNP2LyB4 i260g2wgmmwmNk4BLPBNR60wmNN0mgmyNPy2P2kkw4g4yBiRN yRmNg2m Pg0L6kwkgm PLgiLkB464kRBy k2iRL6L2Rm2mkLBPPwP w6L6ygP 4BikRkyBNBNg6 4Pkw0mwBPm LmL4gPP2Ry2L02R2Pw026m4iw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081158,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":6,"c_w_id":1,"c_first":"wRNNig 4L","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"06g PBmg4kyRLRg","c_street_2":"ikwR24m g yLP gw","c_city":"6B2NL4gik64LNBPBgkm","c_state":"L0","c_zip":"240511111","c_phone":"122-744-6923","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.05,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R 6N02wiy4RNwm24Lyw0ikiRk mRBmw2LmN LP0NmNm00P kyL0 2g4L0mmiwNRN4L2Bg24LR6k4PLgLBR266NB2Rm R wPiPRyi06B4k i0 0yP0B0Liim44yNNkwwiNmg2y4N62Pyw0k66RyByB6RRgLLRLNwPkkmNiBB06kPwN6w4mP4k24Rym62im ymRgLP6B0ywiyL0PNNBNPmPP46wi4 kkyNB4g0LB2LRkB2Lmyykk Nk NBm2","c_data2":"N24 mw y 2gim2BgBR0Bk2 0myPgNg wymyRwgm 0RR2442PRBmB6N26 k2 m2 6ywgmN2Nw0mBLgg0ywkiNk04i2i 6N2y6gmNBB4NPkyB22P6k4B2B0i 6wkmP0BikLLNBPPgk kBRRy62wi4N064R0BwyLgN42B4 NNP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081158,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":7,"c_w_id":1,"c_first":"yy0iyggkw0w","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"g 20 gyBi00gR2kP","c_street_2":"4RmRgkBgwy NLRR","c_city":"iL2Pi 44giLiyP2","c_state":"mL","c_zip":"618111111","c_phone":"225-701-8557","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.097,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" imL6P624iPyNBRRwRiPkP40i 4g B4mwL Bg0y2gmNkwwmBLLkigk6yy20NR0B6kkiB4N60m4BmLLgB iyB664N6w4m0mi0w2Pkkw6PmPLNygPwg NgyB22ykww6 6L6kLP2N2Nk miB00wiB2w4 PNymyL044gLmPPRR mwgNiy6R4wwwgyR6PLmNgi2 miRk2BB06wN2BiiyL44 Lmkwiy k402gwL6gN2 0RP0k46i0P6242kR2m","c_data2":"04PggN2Py2kgm44myL RwL2N0PPyyyw kBwyNRBBPwkRB6P6 60g 4P42P0mmgy6iNP2iw666kL6Nwggg 4g66m6Bg N02Ni0PL iyy4y4Ryig6gwB60wy2yR264RRk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081158,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":8,"c_w_id":1,"c_first":"NRPRNgNRRmRmRk2","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"RNL4y0NwwP","c_street_2":"Ni 262i6m 0","c_city":"y402N0LgB6","c_state":"24","c_zip":"883511111","c_phone":"214-229-6547","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4959,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NgR44Py0g2immPyPk0kNBN2NPBBiimNmiywwmgB42B6N4 N6BBi6m4LP2B6 4mR Bw22wPR4Pm 6Nwmk604Ngw2Lmg Bg2 Pymiw0L0L0iR0gBNwkLkNm0BmPBRLm04kmy0Pyk k222NPL0R6myiR kimL PPkN66LiiBwB6iPPRwRRRwgR0iNP2 P0R4iP2BgBiLm6 w4gRkwg2mmLRN26BRi0B2 LmNyL2mByN0g4L0PPw0 26BR B k","c_data2":"L6m6gNRm0P42ikL064gPgL N2mgwPy 2m20kL62PN0 LPyN0LLR0RRiPNigNyLigN wyiyR2i2NymwP2B2LNkyR4NkP0y 4B66m6 m6B40kR2gPRgmg0myL 6ki RRw6mwiPgkBkyLy64 gy0Lmyi02k4mBi002g2PwBgmykkP4wPww 4 mwm0m40mgL R6LgNywP0P0L2w2RBw2B0Bg 64y RPL0Nmy42m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081159,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":9,"c_w_id":1,"c_first":"gBm4k0B2Rg","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"i2mLg6i024N Rg 2iy","c_street_2":"6PyN44BmPi4g","c_city":"6yi6kLR06kmPL","c_state":"wN","c_zip":"820911111","c_phone":"977-138-8347","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.3773,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R44mky 64i6N g i2i064mNBmB0w0mmwy2wiLR0RPNPNgLg4BR66iwRB R4 y6mRBmk wkLLg 6PNk062L LmNk4w 0Bwy 0PiP0kL2 wR0N6kPiRmywR04B44 2NiN60iyygPgBmgym yk4igN4PNgkiBmL6RL mi6Piw6iP2 Li6 ywL0PP26BR0RNP6BNBR6N 2B0gg 4iN2y4RkR BkNi40PPL2N m6mP0iNyk4w4yL2y0k w0L","c_data2":"PNwgw iLP6gRPkR6mNPyiP4gL6 PwRgykgRLRgPB6k0NRwLRNNRk2LR4g40 P602yBLBw6RNiN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081159,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":10,"c_w_id":1,"c_first":"PR LR 6gLkkk","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"g6LwPR m2yyymw0gP6N","c_street_2":"wBBiRmkki6mLw2P0","c_city":"iimyP6gLBR0N2kR","c_state":"ig","c_zip":"373011111","c_phone":"725-826-8430","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1812,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LN2606PmL0LkBm4mRB62P60mk0LPgRmBg4wNg2iiPmmgNy42BB0 24mk04Py0R 6Pw m2 gmLNm0N i4g4yw kRgy0PykmR4yPPymww 0kRPwyNL44R g4mBmykL4mwm0 iPP6LRP0i gBBLg0g L06wNPNwPN yygg2m64kLw2PLRB4Pi666m6yigmN6giR6yyLLPimRiN6wimgwww0mLgkkBg i4kmPw00kk4RRw6B BRmimLN2","c_data2":"gkBPiP0mg2gmB2Lm4gkRy BBNNw20mmg0P2R4wkgm0iy0ymwwyy2k 4yi4k yg0y yBy24ggPNBmR4PR26PmLPgy20i w00wBgRw60BkgNy2 2g4Lmm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081159,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":1,"c_w_id":1,"c_first":"giywRLm6BN","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"w6PRgmgi yL 6igN","c_street_2":"P2wymymL i","c_city":"BLywm gyNwi y","c_state":"6k","c_zip":"427611111","c_phone":"141-748-3048","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0743,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"Pw2gR2y4iB0R2w0NB0w0iLBykmimBkm6yB04wR6L2RLiRgyLBy PkRN44PkgR6N2ky2 wigR60y6PByBR242PgPy 6y2L L0 R6ByRyRRgmygw yRBLB46Ly02RBLwm4mR66w26NwkNg6LRN2R 2PLmwkwyP2LwLy0mwkRPN y64k2iwL0mBRBLi0N 2NNNmN Nk6ggRyNL6mmwLNPw w6R2RBB0w404P4B Pg m2N0L 0gkLL2w24Pm","c_data2":"LLRmRgPiw0m0ik kwiyRPR60B2 y0iB02wRmw0m0B PwBNwiPwgRL2 mgNL2 ymNP0i0mkkLL44ykk0RiLmg 200RkRiNN46iiBPgy66Bky0m0R6 20wgBkwwBB iBP2P60gyi40 P2N gkB NRyNkNmP064 4yyLyRigg4gyywwP 6ymN62iy00kLBLN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081160,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":2,"c_w_id":1,"c_first":"BiLLNwRygy6 6L","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"6 0gRR4 6mwmLyB","c_street_2":"y4m24gBi4iwkLB 4k0Nk","c_city":"k0BwN 64w4y6B6yk2","c_state":"y6","c_zip":"330111111","c_phone":"708-262-3397","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4474,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"4m4Nwiiiikg kkiRLP4g40g0y0myymg B Pwi0NNPy0 iLy2m24 4L2N44LwRgkmB0g6k2kL6 64kN4NN4 k2BgNR6iBw4LRw0 wiL2k 0yPkPgyg2w0i6P i BkBN6 2y 0iRPNBkkiPwiBB4N4yy62NLwPBiLNwyi0ykRk4k6yiBm4BL wk0Rm2N0B2022Lk0giLgw6kNNyLNPBBgRmN64R2B2RPPRmB4mLw0NL4igB6 06BiB kk","c_data2":"wkg NRi6m mBP24yPNii04NN0R6LgRywi0y6yR2BkkiBPgN0mk0RP460wwN2mg2N4Ng0Bgmg0y6By2gRm4ggy02kRkggNmm26kNNBRLNmi4y2iLNy60mB6 N4NiPBk2B0kP2ygPkPBL6P kNiNmik6PRRBLNNR6im0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081160,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081160,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":4,"c_w_id":1,"c_first":"2BmiBwLk4mkLRw","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"gL6 NiP Li0 y64","c_street_2":"B 6NykP4gik","c_city":"R20PyPP6 R0mi","c_state":"6B","c_zip":"574111111","c_phone":"372-875-8911","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0718,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2Ry6 kPB2N6kBkiP2iR4PNiLyg4LNRLP20wyN44642ywRyRw2wR22w 24ikmw6N4yN2ywNw6kwRwmLR0m6 NmkmNNii y6giwwm240ByLwPgR4wmBgyN6yyBiNPkB4iyRmwNP w0imkRmN00BmmmByiRkNkym6m kBkgyim2N Pk42PNNB0RRii 6wP0PNyi44004NR4R6NBggyR46626mwgBwm4NBNy 2imywg2mLgL46P2BkmkimyggR","c_data2":"2Rgy6NP kyii k2yBkw6NB2gkPPwmi4 0igLPBk0ykPkyw mg46g6mNPmB BigN0iBLkg0y6B 4ygm2ik4wPy62gPRgm4R0P2P mRg iRwPgB4y066wNLNByw62PPmgmgBg2w2B24 B PkL2y k 2kNg4kikLLmgBBi46PwyNL6 w4gkmRi2042mLNiNiiLRgkB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081160,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":5,"c_w_id":1,"c_first":"RkgyL4B22g2m 0mR","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"0000wgmg00g","c_street_2":"ky g2k Pk kNP","c_city":"ygRBiN0iyy","c_state":"g6","c_zip":"438411111","c_phone":"459-899-3839","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4863,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kPg0yBBy0R0kP0NgmB mii2L gwgN46PkRgNgwmB0LB4Byk6kky2BL R2gk0L2Lyg6 iiPiPiyBN iiRBRPBkygPmwB2ykymiiyRm m 2iP m00kLg0 g 46mBgymP4i6i N2B w6RBmw 22i2ig22wN4 RmgRwBNwPwP PygmkN20B2iikkLBi y0mNP 2y NLkNk RkLByNkgykmikPLmRymkBBgRgPNB BNL0yy0L iR 6kiNBmL0","c_data2":"miyBk2BL6yywPLB06wwy2kw mLwN4LBgL2 g02y2iBPyi PwNL PR0RyPBw6PgiNNmi6L042 2kgNw0ygRiig"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081160,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":6,"c_w_id":1,"c_first":"6mi440Riym2giB0N","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"m6NN6wmLB22w","c_street_2":"wg6gi0Ry Ry6gN","c_city":"kLm6Lgw40wgP","c_state":"RB","c_zip":"582411111","c_phone":"819-570-4009","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0432,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"0mmkNNB04iw m46w0Nkymk 2LyPy4Pk L0m6kNw6LR2400BiPRBB RNw66i LwyLwi k2mi0i0gB iNg4R6Ri0NRNiBgNyB04Rgk4gLL060B 6gg kBP0wL2gyPBiB iB6kRwmiBkN0Bm mwiwyw0wBBBimk46k6 mL Lk0mykwwgw2LyN4BBLmPPPNikL4m60R2Pm002LmwL2LRRm6 Rg6L 644k2Rw2Rii6L NR4yBR4 6w2kN4","c_data2":"wk LLy gkmB42ii44NRPw626iNgiNNyyRgN4 022B6LNRk6Pk4Bg2wyR4ggiywR060RN244wP62kL2 0wii mgLiR6iN4NBNgygRwi kwyN6wL0mLwyyP22i2 B2NwyNk RLBwPk62wmwk0P20mgw6gmkB 2NyP4By6ki Pw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081160,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":7,"c_w_id":1,"c_first":"iPm424 Lmy0k","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"2i4mL k6gNmi","c_street_2":"4iwR0622L kBL","c_city":"kgP4L gymww2 Rmi20R","c_state":"4m","c_zip":"703711111","c_phone":"658-548-9159","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1597,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" 4R20RBBwkg2L Py w26i02PP0 PgPgyNw422222mkwig64gyyB0 2g 22y6PB2yBi2gy04B2wR2RLgyRkPR2wNk266N6 LBRmN0PLi4LB40PR6PmRiwN4k y0 0mNwkikm4yw46RmiNwLNg ByLkiwwPPBm 24k6yyNR 42y kLgwNk62Pw6ii kNgR2iR02N0kL66 R4i0PBwyRiPRiRyPy44wwyg 2RkNLBkL22P 6NiBBBkymmm0m","c_data2":"6NygyyykmBRRNBmiwLP6y066BBRg4Ri2LkiyP2 mw2i0B4Lg0gy2i26BPkNB0Rm 2k y0wNBNggm2Lkyg0kRL2R4k R24 4N6066wBRiwNiRwm66 m442i6NN4g wii0g PNw0BN iB2yyNNNmLgwB 42P6g miLLPyg6ywP446mikPkki64k46PRyBm y i0LNLR00Pk4 PggwNyR6wkkB4kL g0mw mwB66yByN 46BkPNkBm44k2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081161,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":8,"c_w_id":1,"c_first":"2NiBmkk0gmP","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"2P y0kPNLBN6P mgw2","c_street_2":"L4NyPiLmB2gRw0B0ym6R","c_city":"Ri m6mk kyymR00R","c_state":"wy","c_zip":"693411111","c_phone":"161-513-3639","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1185,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PR B0R 0imkN06Pk4m Rk4y200RwBwNmkPi0Lm40gLNNPRg2B2N0LwiBi g k0PyymyNg6kiyN2g0R4Lg6iimRL2y0B044L0myPP6kyPyBmyy0wm6wPmg4NN Pm4 4iiww2iLyB2kLPgmkyN6m 2wiwy6RB 4ygB20gywRR0k0mi 4244BggRk4PN4P 24mkwNLg R4mBR0Lw6ykg iLBwiwwi kk4kgwyP 4B6PB BiiBR2N N4m4 4R","c_data2":"2600RNBwkigyPN64 26mP NkR6P6ykw g4i6B2kkmkwyk2LNkL0NyBymPky 2Rw402i6kPRBi4gR kgw66B2mBR0Rk4L6 Bi2i 6gkk20NiLg6B4NLRRR ywN2g02mgw ym0w mNPmiyN6i2iPwNkgNyBiik0206k40PPgPkRykN 4wi6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081161,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":9,"c_w_id":1,"c_first":" Bw6P2igNNm0","c_middle":"OE","c_last":"BARBARABLE","c_street_1":" 4gy2g20 0w0","c_street_2":"6wgLkN6mk 0PRLiR6LL","c_city":"kymkyPmmkgB0R","c_state":"mw","c_zip":"738111111","c_phone":"369-429-1671","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3581,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"04N2mR0LRRyRyNN62wPNmNyyPgRNPRByg6kPy R2NBLLLNiP0P4ii00 m4B046B2g4RPwgPP PgNwwyB22i0k L6P4 4 m6LiyygyLg6mywByy ii4 L24Pk6ggBL02gPgNg0mNPPRm4 B6RN24LB yByP0B6Nmwyk LyR 4yyL62RLN46k42kNLNiLkB64m6iPk2mPgL2wiR2gBNRiPmRN42Rg2k2gm06k 6migR0iBwiwkyN464k4k","c_data2":"m22PLB4BRR6PwB4y BmwP4yg4i6RkRPm22k62gykBRwBk6Bi2 PBN606L40Ng6kRiBkg44 By4mm4wR6kkRmLLyR 4LByiwBiiNR4RLk6y6 62gwRP4Lg6wNkwyRy kwmRPi yPRm0PPyRkyyPw6ggmBB0kPg mgiLw00 66LNRyRw6mm20mkPNg g4 2NwNBwg NN6i 2RNP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081161,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":10,"c_w_id":1,"c_first":"NLBBRy04wmRBiP4g","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"wwRP2iR6yw2R","c_street_2":"LkL2mLNyi6kPLBgP4wy","c_city":"BLyiR2kgwmR6","c_state":"PB","c_zip":"173011111","c_phone":"922-300-3532","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0791,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"66400wNN4ki6mNmkRgPNwkkB Ni 22ygw4R24Lkyk PLP4 2PiN6wiRmkPiRkRRw6y40mRPNBRN4PBgwwNy460NPP6B6BymB2y4R4wk6P0yggNg2ig LPRBiR NmRN06imLm0m66gLmRLmBRgRmk2BRRiRPP 4P2N6gwiiLy4BBNBm4LmBLN RPkgw6Bi0w2NN6026m6mNPyB2PBkNP60R042NPiw6RNPPkym 060PPNkkiLg mPLPkB2g","c_data2":"Rgi2wNRyy44Nyi024NgPP4Rm0Ly04Bg60mmL P4wkPNBwik0 40y4LwNPik RgmBmykw0RB2mw i yPk6RggwN6Nkmw6w w0mBwki 2mmNk6myi6mwy6m66iLBRLwNBygBwNLgRy6B6N0Byy4 LNm6 2NNk4Li6BRyN6PPg2kNL2mi0wNNgN Rkw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081161,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":1,"c_w_id":1,"c_first":"PR262iBBy4R6","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"Ry2iLR0w 64NNy0P N","c_street_2":"Ni 6kgRR02y","c_city":"BNmRRP2066m","c_state":"6P","c_zip":"749311111","c_phone":"543-231-3696","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" N464R6P6gNLii4iw0BkN4R0ymB0imy6Lw2LiPR460L022NLyPi02k0B2i6ikiwRBB0yBRyBwN2BP0yk g6 0BmR B6Nyw2iN62gLimBLB6i6L4Rig4NN2 mkgkkm 64i2Lwkikkw0 g0mmgNwPgNNiwii04Lyyw0ygii6 L4gRNR4P046PwmR0LmkRR62 mggi imNiiByy606 0kmR02PLyiLw2BPRw0R 6 ym00 BikPg4w0y4PPmy4","c_data2":"PmN4N0kwR62g 44kwwy6LRL2LwmLy 0R6yyRNykyLPB 00m yR62N04RBB6igi2yi4gw 20Nm myw B6LP26 RygLBB2 2Nm0k2RkmLiN4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081161,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":2,"c_w_id":1,"c_first":"miNi0BPPNkR","c_middle":"OE","c_last":"BARBARPRI","c_street_1":" 4yw6BBi0RwNNkR","c_street_2":"4wmwL6NyLRkwLw","c_city":"yP4gmiBNkmy0","c_state":"kk","c_zip":"440911111","c_phone":"304-594-6359","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4999,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wPwgR2igk2NPL26LmNy Rm6gm2kki4wLkk6N2y2B yPmB4BkPNiw2i64k6RLL4 Lk 6R4w6NNRLNg2LkgimwkR46kRNwNPR0LmBk2 kLkBR46PLwBNPN2RkkNPPN24Ni260iPNyi0LwB PPmN4Rgw64BRyiyPiNw N wiN Lk4 LN6iBP0wkRLRm i2Bw2 NRgm4mkBkikPkB4gBywL PBgN0RwRRi60N4 2LiLyyLN0y 24ky0By0y6Lw","c_data2":"BgP4P66kwkmmLykkPkig62P2yyi PPyikwP22mi6imN46yk2Lk2RwPPi6RB62 im04LPNRByPBBkm BB6B0gN2Pg B0 6Rm2m0Bk446g4w6 w mm6B2ByP mR Bg42RNBi4y4ig2ikNi0Rk0BgPLwPgk 6ByB k iLi4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081161,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081161,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":4,"c_w_id":1,"c_first":"24RRBRL6y4m","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"gwNLkNk60gPw","c_street_2":"wNk0 6 mL P","c_city":"yR46gikR4yP2wk2k0","c_state":"kg","c_zip":"614311111","c_phone":"868-789-7458","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0553,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iPiNRP40 gR4g0N2L4kg6LygBLyPkBk6B22w6gP44kk4PwNym2N0ygg4wgNgL 42mBgBRL60gP BmRm 202ig6mymNk0mkkPLN4k0 gyywPi 6y2R2k0N i2B44ik0R04N0kg6P4ggRmPy2RkBiPgm06N4RP44R02NwPRP2y6gg0PP4kgNBRNLNiR0PiNmm4L42gBLB60k 4i4gy6N PiNkgky gLRNw206Py6mii44N24Rwgw6NykR2RR","c_data2":"L4mLBgg00 6m6NgN wi Rm2kPBiPNiimLwiRR04i4yywRPRP0PwPLB6N4B gwB4iB2iiBPBwRy64gNg622 kR0RNyL206iw0wi wgkwyNkBwBii26kRBLR0N6wyRwkg444RPNLPLNw6gwmw4mLL 2i yyLRm6Pim4yyg6L4LBkB662NwBigw0gLwPgP2R4yi40RRiL2ywP0k4yLRy2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":5,"c_w_id":1,"c_first":"0Rk4k64L0yiLg22","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"PkmL6yBLkRkmNP0k6P","c_street_2":"m0km4ym66Ri600R0Ri","c_city":"Ly4wPL22Rk2miik 2m0","c_state":"6N","c_zip":"504811111","c_phone":"625-239-6680","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.3864,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"ywimBkLgN60y0wgL 0R k LPmky2iN4Pyyyi0ww260kkkBRyR Nww2kBNBB2ikykmBkw2 y2gyBy6 R0y4L0PkwNyL6L2kL6mw R4wiky2Bki y04LwL 2 i6ymyiPBPkR246B0mB6yRm20NkR0wyy wmwL6N6 wy4 g6ikR4wR60k0P0wywPg44yiP6PBBm 2imR LLgBgkg44ym2B2N22mw0RP gmLkL4B0LBg2BNPL kRm6k00RgL06","c_data2":" BmLNNk6Nk42kwwLikg4gPPg6 Bi0N B4kwN0ByNgLP42Pwgy0iwNwRggiygRmmPLPg4N0B6ywL42gwig B4L NBB4Pw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":6,"c_w_id":1,"c_first":"2ww64mgRP","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"g4y0RRiLgBig0BRRg426","c_street_2":"44PyPw60PP2m26","c_city":"6yBgi64mgmmiiL00","c_state":"42","c_zip":"052211111","c_phone":"164-678-6958","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3827,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"N4 Ni2w2kg wyPRNR440PNPi406k42NNkLB4wy62mRR iwNPR gPgkigg4 im R2 y62L B60Pw00imiP04LLLLmL0wBLiLBkmgwm26m ggL206NP6PLw6RLLNm2NP4NPPyB g0 NwkkPBwkyN LmPgBk06B 2 m6R4iyRR6yB Bkk y yLkN0R0yiPLkiiy6PNNR6ymg2wPRm2kwy 4mggk6BLwg40g26NwwymN4 w iPLy 2i0Rig2N","c_data2":"RP442PgiB2w Bw60w LR2P4N Bim0iL0Liw4BLmBPgPgi Pg2mL2i6w4mPg0yBR4B y644wkkwkgiBN64 02kP4kPNR60i40NBgmB6 LP0kk RP 4gNgLkLk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":7,"c_w_id":1,"c_first":"0kyy2PgNkPBB","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"gRRmRgLPP04m2gk 2N02","c_street_2":"kkyiNiy24w4ki0","c_city":"2wRyR4y6mkP4BB0yL","c_state":"42","c_zip":"316611111","c_phone":"535-184-7311","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0851,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LP P wLky6L LRgyL2wm ik0m04 igiBPiRm4iP0NR6NgywiRgmikywm0iik4 60Ly4 yw02N4k0BNPmyBiw4km202Nk 64wLy w2RL6m44yLg6Bg PywLkgi4wm606yRyPik ig6PPyNmNymwNRPiP2gPRwN0Ni6B w2y0gy26kPR6R4 yP m 0wyB4Pi4Li4 kB6Lwi6wmgkBm4 NRmyRLkmRRiw44k4B6g026g6RgwgwymmkggN4 4k","c_data2":"gk4kikm2L 4 BkgRw6mLBBkyN6iLgi2P mgm2LkPwBgiwkii4NP2y2ym0k4LR L2iP RN4k62Rm02i LkyR44LN6PkBgi6yk0P4 iimgNwkgNwRgPNNB 0B4w4y2NNwy0RwmgwmmNw62i66mi2giNR6BkRPLNw4 26PB0g2mi6PN4LNw6gPPiR B2 gLw42LgPRNRPRB206kmP464 6Bi2g BNNLyPk 4 LL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":8,"c_w_id":1,"c_first":"yPgPkNwy64044Nk","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"wy24Ni0B2LNPLy","c_street_2":"4BB6NN4BRyyiR w4i","c_city":"k26mB2ywRP66igLggy","c_state":"gw","c_zip":"168111111","c_phone":"605-417-4479","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.103,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R4L46RBLw mR62RRmP6BRwm24yg004iNmyBk62ykki0 0i0L B00wwR0 kiwkN6iN4RNNRw24Ngwk wRyk4464BNLwNm6mB06B4Rg2PNLiPRmm22gBw2P4w6R6gR46g2P0gk6200L4 4 4w4wB iim RBgmyLkgywwN0 ywNRwNkmBgm4gR 46ygRRBPNiN0L0 2iPy L6LPkBBk624igg4Biw4wi N24iggiP4ywL4wLm0m 4 2m6y","c_data2":"P0NgNBNikRwPyLLRkmkkk4L4w2kN2BN yy0kg4miPi kPLkiiLRP2g iw P2i2k2kiwRmi my064wgPPwLBg06mBkNLRi606iB 22m66LP Lii6R4y06NL4yNik4iwB62wBBgk62mkRR6 LwRik2PmLBkwwN mg0g6 gy4k0ikByR 44L BPgwNyi4iB24P6BR2NBg6w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":9,"c_w_id":1,"c_first":"0P 6kgkLyy22","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"iiik BL0kRL6ii","c_street_2":"g6R0LRwPiB4NR0L 20","c_city":"LkwNi NwB i","c_state":"Bi","c_zip":"392611111","c_phone":"545-767-9187","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.246,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i6BkkB4wRP2PkkLP2Pw06gmgBmPN4RBgRwg Nk0mLmkkRg4LyyBPLPLLPP2wykNwymR 4BiiL26yLP2iiNL4RPNiByLiN2NNy y402wB2gLLw0iNyRykyN wLk NRRk2wiy6g6Riiwki6BLy0yyBmLB6iwy4B kw0N4NR2 Ngm2im2gwgm0y mkN0N i2mm4kB062N4LP4g0P66BkBkLg2PwwiNL0wy4P RkigP RNB20 0wwi2Bwy46m","c_data2":"2mPBkP4my02PyB0R 0 0y4 PL4Lwiywkwmw 00y 46ggL4gRwy2mN64iPy6wBPN42k4N26mk2BywN 4PR6wR 26RRykNy2ykLBm2B2NPy2L Bm2 LLNL440L0 B24i2 2R64mgmgPgNPPkR BLRNR m0P 2Bm kwmgwm 2640gyP6Ny2RiyyP w202N4Nkm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":10,"c_w_id":1,"c_first":" P 0k46RwwmPm4k","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"6B2NP4RPg6N6 L2Ny0","c_street_2":"4yRBg 0B662RmmygRm4R","c_city":"NNNB2 w4y0BB i0","c_state":"Pw","c_zip":"777011111","c_phone":"872-877-9126","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4281,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"w0im2giL6wmiP22 PmL4Pg4LB6 N2iB 4gw2Pi4gwgi0i y Rk0P Ly6B6N0RLL40BBNwBm2NRR 2m2P2gP0NBk4LNR0ky4Lm0g6P2NgPmwL62LymmwR4yiPLmg22g4k6iPgyR0gm62PkmBy ykyP6wgmww4PN4yRNiPkR wmkmNBPN0N2NB0k22kPwy0 0N0BgBw4B2gwkgiyRw Bik2gBLNiPPPP2im46kyBPRm6gB6RR4LLwNPBBwmg","c_data2":"2i6NNBgiiBimP0Lyiy 6gy0mwmNyBRB4 g0i64LmN g44mg6kgN2RB02mikgkk6 Rm42i i6Bgm2w0g6Rwgi0BPByRNkkkg6yw0ygRiPwwiP4R0g44yyyygmPLmR2gR R0imi264gLRywNPygBgikwBmN22NL064kB4mk4N0Ly0NyiP gmmyi mRiP22y2i4iyg4LB4g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":1,"c_w_id":1,"c_first":"LR26Ly4gmyk gNNN","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"i40Rgwmw2NL64Lg6","c_street_2":"NRB6im mw446gg","c_city":"BNy4kk 4myw","c_state":" k","c_zip":"417911111","c_phone":"626-159-6908","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1136,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"4myRRLB02 gBwm0iiPB4kNPiLg0iw460 mPgkP6L4NRkiLg40m2 B 26P2PkmPiy26k66BLyRPg24kBgRiBRRLik2NP262m L 0imigPP2g4 22NN6mNk 0LywyLwiwNwm4PLR26ykNyNgBB42 44 0B42LkwBL kB NNPRRRmBR6m0RgBL0y2RiLNP22Lwgw0yPBRy46kNyLLkRRNmymP6024yN0 mgB PBPmw NwmkLLP02yNw064g0L","c_data2":"LmRi206k0wNmwBBwkR604yk2yw0LNw0kN4iBN4L4kP64kyR4w4i6miRy6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":2,"c_w_id":1,"c_first":"ikyg4k6kRN","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"444gwPiPi2L2BmPB","c_street_2":"k2yN km2ykB2R22Pk","c_city":"kgLgkR6Nw 0wiyy","c_state":"62","c_zip":"423511111","c_phone":"874-658-7159","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2301,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gP0kNLLR40R2wBNmkkkikLLBLLN04 wmy0wRmmkRyPPRwmNRiwNyi624w0kNPkyB2464yL2k6ywB6PB4w40kBPPwiBPy6RigR2wgPByPP0PkPRgg2L26gPRNwNiNNwB4 i0NmLimPL2R0 iLk6gN6L 02R kkLNNkiPgkLgN6w6y6yyPmgBB20RR6yP2mL0NiN0 wB4yk22wyPLNL226yNRPwNygRRkw6yiPBimBBm Pm2 wkPw4 R6L","c_data2":"iBmiwgmPLBkRkPkwNmyNNLP0Bwg y4R0gywPkBN66kiggL0mg4w02 2Lgg240LP2 P20 Ni6NP y04wNy40gPRyN2Py Bmi4NRBwP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081162,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":4,"c_w_id":1,"c_first":"gg gRRy","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"2km6gRkm6R0iwg i","c_street_2":"0 RmiRBB N","c_city":"RNyg66Lk44L","c_state":"gg","c_zip":"944811111","c_phone":"437-940-9933","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.381,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"0RL 00L6yggy2NBPg06k2kwiL0m 0wm4LiLiRiykkNNm44 NN 4B mRLw44By6i0R 46m06igP60i2NBkg 2w0mP2LPy4PwR22gNN224wwNy4kBLP6gmB0gwLyR442yyPk4ww6ywN606gB64kg 2B4B40mwLiiyL0k0Rimy6gkPgNB4BP4PgPyyy6R2BNgw0B R4BNy6im06w6ggyB2ykwL4im4042miw my Ny L N0y2B40Bg gwiNy0","c_data2":"mPyL206m6L6kw62N4Pmwi0mL4LB46m4BPPLLBRiP60N0 LmLi2g gk0g R4m0B4wRNBk2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":5,"c_w_id":1,"c_first":"44Nm6gR2","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"0Rwm 40B PB k60iL2 y","c_street_2":"Lk4N w0N2k","c_city":"L yLg4miPg0BkmLkBN","c_state":"RN","c_zip":"101111111","c_phone":"607-344-1831","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.2285,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"mRL6RgNwmmgiyPP26kLR4iP02mw w2yP6NyL4gw40yg2PkB02mR2 44BwRk2N0ym64y4 LBiiw0 46y4i0L6gy24 BLBRg0P y46w2iN Pmkm0wR2iPP6NRw0iiLBgB2Ng62yBBwNRBmP06RPi P06ym44wy0igy0wB0P mPkN6L6iL gmRRkmNiRNBBR2N0g06g6mB4gk4Lm2PBBN4RkiPmNLwgii4w iwg 0Bw46gwByLkLiBw0w2L R","c_data2":"NN26g2R RPPNyg4NkR4gB422B2B2yPRNyi02kP Ry0P0m6PmiBBw0P0w4yyNkywNwNmLgNg0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":6,"c_w_id":1,"c_first":" yimR0kiiwR6P","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"y2L642Rmm42","c_street_2":" 0gLw mRL244PLR","c_city":"mLy2wkNyLRgmB4w60k","c_state":"mm","c_zip":"394611111","c_phone":"411-284-8513","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4375,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kgLw6k6NP2ggPm6 i PgkR6mBP6NP00P N40kkm L464ym0i2wiRkNNiNkN4y2i4P6km NykNRgiPL2iRN iiLyg20LNN4wNwm42wL4NkRyP2wi66RygkN6Bg0w6mPwyRg 0i6iPNg6i mN0gy B4 ky0 gm2gLBwwR20mRN mPgyLyL2PPm0Lm6BLkRmBPNw4R0yy 4g2Rk 0Nyyyw LRkiRiwkP B0kPi 2P2 N gwNN0y 0BwymRiB","c_data2":"mg26606kk60 k0PPw6L 26iwmBgmiR6L4R6m4L0gk6w6P04NyikBN4w0P0kRLRi wkNkwL62iwy w420iikPmiRgNg 0k RyLgmPk4R660yP0w0LNmm6 wmRiRRg2kRkw PiwyPmPLiLLgRg6mw wPw 4NNg06N0ky 4ik LP0wPPgyyNwmLii6N44 Bm4NRRwNLgk6Lgm6B2PLm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":7,"c_w_id":1,"c_first":"0B00P0w4LNy","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"Nkim0iwy0PkB0m","c_street_2":"RNRw2LLLgyiLNw2N0kN","c_city":"g0wk6260RBLL","c_state":"Ng","c_zip":"752411111","c_phone":"551-383-7570","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4234,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"L2 4gPg2kRBN2Nk66PNPkgkkBL6602kBkBL60Ng606264 mLN026Piw6gkigB6mmgB6P00ykykwmB BkLPPPy42wLNR22wNBk6P40 4kigmi Nw 4ki6LPi 66Bgym2y4mkLgByByNi2 yRkgP20iBy 6R2w4R2PLNR Ryg g64yy6 6yy6N6BgB0BNm2gmBwLikLLB0w4w0w06RLi2NLBg46 gNgPggR0RPi2w km2kwwN2P RPi k m","c_data2":"ww4gwRi4gy4PNN0w6LPPy6g2giyPki2Pkm 6PP0LR0L0Bm24i60PNP40mgim4y4 00P yy4iBi4i4 w6LBm46yBiwmLw60NPBPiL iLky2Pig2wyBmBN2wyk4N gwg2NimyiggyBPPL LiBN yL4L2BBR46k2wi400ykR0gg2yiNymPiim4BPPigN LikkBwy4Lmiw R4yki m R4BP22BwPwLigNwkwm0i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":8,"c_w_id":1,"c_first":"iNiLNR P Py","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"4y6i0BNkgmP2gwgyL","c_street_2":"g2wgR iRiigRiRiL","c_city":"2y4Rg026gBimgw","c_state":"NP","c_zip":"769411111","c_phone":"456-688-8303","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0917,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"44LNLN4N0 BPwPN LNNB04RPg2 wiwmBikkRmNNi4mN0BB NPgNR6 iigBR2wRwR2Piw 4LwywgiPNgPNL4P RkLggB0LyR66Bg2wgmRi6PyyL2Pw6 P0NB RmBP0i2g L4g4Bm6kwLi w62LNBRNL2yyyNBgyN4Rg N6my2RBLNPm4PByR m2k4 ggmBk4 LRyikPLPRm6 wy4Pw2ky4Bk44BPgyw 2L 4m04im62Pgw4kRmB6immy02L","c_data2":" ymR02Bg yPmyi42PyRRiB640PiBL4RR0R06wRN224yNggg60 kky60w2ym64wRwgmN20B6yN0i0iPL0Bmm2BRkBk 4R22iy6R6RP P 0 ymLm0L642i4g6P P6wk6 gi24PywkN6Ryi40PP4iN0 wiRP2LB Ly PL4RBgk2PyL26gB2RkmyBymB0L2BmP BBygPP 4wR4026NPPw44 gR24BgNBP22RR4k6wRLiRkmg2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":9,"c_w_id":1,"c_first":"mBm00i6BiP6mw02m","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"wmPmiP BLiwi0BP0LgR","c_street_2":"LPLRiN22wPN22BPmL26","c_city":"gwgy6BBkLy","c_state":"mk","c_zip":"753611111","c_phone":"153-928-8177","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0315,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"ig40wyBP2gPR06gk24P0P4mmiLP4yiyPPwPkwP2 BNN0k4ig4kkPkN k0L4mNB6kg 46yiy00wk6Lkm6iB24R66i B0kk6Bkk46P0R2Py4y2Lg46Pw6iwwii6mkk2w mm 42g06RkNykg0gk6Lk4RimByiwLw0PL0PmmyNwRBBgPm 06N0624P4Ng00Lm LRm4B4R2RR BwBy2Lgi60wiy46Pyw46ii 06g40404gw BLBmPmiByBwiwm","c_data2":"RRP6gw 2k042ww22ww2gPwP02mwLw4NPNk0mPRNL4wLwR4wPBR2ki4mgNmNP4R6 i Nmw6ym2k i0LNgB2ikw yLPg4RmgB24RiR4mPN24BBRPgP4iRRRRBkgRkyiy Lggk g2 mN2kN ii6iB20PmBkBBLN24m2R40g4w4LiiNkLwiLi0g4wP 0BNyyRy26ig6giyw2m6Py"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":10,"c_w_id":1,"c_first":"R4B2mk6R","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"2R0B0i2PyyN","c_street_2":"PR4k446kP P","c_city":"2PR6mNkL 464yi","c_state":"gi","c_zip":"772511111","c_phone":"918-906-3675","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.0038,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2mP02wwLP60BmLwN2w4LmwiiPy BL6ym0 wP2kyiBm4L0w0iL img62 k0gL BNwykm4igPmik6LLBk4B0 wi2B6wL4mwyR2B gRkgkBB BwLR 06244BBw4g6Rw44gmNgB64PL44y0gi mgNPykkkBmR0RPgP2wiy 2w6gB6y42yyBRBByii wiPwkByBwgkgNN0 PiLw4Nmg4kPBRkkRBN6yPwgiB y2PRiBm2kLm6 6R6gw 6LmkL64","c_data2":"y22iw0Bk6i24wPNy 2Bg6yiBL0LB0mNPgPRLgBgP20N6i0mmmg LwyLByg42R6mmmLig ymP264ikmi2PPgPwBL4BmNgmR 4B2Lg0PPm20gm6gggkNNyyy0wLyLP0ymL6yikL2k0wR4BRgNyBBk L4NBii6 0RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081163,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":2,"c_w_id":1,"c_first":"6w4iww 2kg20 R","c_middle":"OE","c_last":"BARBARESE","c_street_1":"yPy ky0B02yPNLmkygyP","c_street_2":"gB B04m6 y6BkLP20","c_city":"L2 ikPkkNP0LB2w4 06y","c_state":"iB","c_zip":"769911111","c_phone":"953-451-4977","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1013,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"Rygg2 2w0R4iNN0NiiPLyiLwPyPwiBi664yimiPiBN0kLi020RRkgiBLyN0PPRPgikNmwiiNky6R42Ng w0P2kkRiwR2 Liy4g2Bm4P0i 2y4RNLBBLLPmy20yPNm iyLw2mgRRR2g2iw2gw4PgPwNRPyw004RPB6PLB2Bkw2g0yki6LP26 NNw wi mw4kwNL0wLNB2kykkg0Bmg4BiL2LgPiPggNkPLgmL4BmLBg2NgkgR42Bg4N2mR4","c_data2":"mRBm62k Bi20BLNB LN NmRP4LkL6gBL42i22i NmB iww6wggBkwgwiRRg2BBP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":4,"c_w_id":1,"c_first":"mkiymmR4gyi PL","c_middle":"OE","c_last":"BARBARESE","c_street_1":"g20iRi mk2kPy62gi0N","c_street_2":"mRNkR y2 Ry0w kgN","c_city":"w06kwPywyLw44y","c_state":"P2","c_zip":"023511111","c_phone":"816-833-4268","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0106,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wRBwRLB 2P2yNN6k4LNmNR 0B2By0yLBBwP 00R6yyyNR64wRBy60mRkPy404w00L22kkP6y0LimBLByk6mk 0yB NN24yykkyi6yRLmL6042LgR426wBwN64BRw2kL4PLkPy mgBN606wy26ym6B2igBkNB64kwLLwwBii42P4gmyBw0yw6g6i62PPwR2y 2RRm PLRywk0yNBykgNBk6gRmL2B24gmPyN 4 NB2PkmRigPkiw64RL0","c_data2":"gi6Li BmNg62 g24RLPP0wRyg wiwNNm0B Rki2 6iNNByP260g 6iByNikBP y2Lm06w2BgPP04BmPLNB620LmNN2kyk PLyN 2wmwkNkmNi6Lm0BLLwwk 4wNii mNm0RP00BkNRLBw4myg4RmmBmBLBLNP02kPN2gP0PByiiL0B0iwyLPiwwPNN w26ByPgNRPg0gwi22"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":5,"c_w_id":1,"c_first":"yPgR gk6RLk","c_middle":"OE","c_last":"BARBARESE","c_street_1":" y 4BNyw 46Pg ki4N6L","c_street_2":"L2kLkNi 6BggLB2","c_city":" k4 g 6BLwP6B4","c_state":"i","c_zip":"252311111","c_phone":"472-120-1296","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1723,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"P24mwy6wgmkwPwL0 6kgmw6PykimP0k6kP0Lg2L4 L4mwkwRP04wg2gLR6ki4RgPy0w2w42mRR4y 2R6wwNP0NmPi2 4B46R4iL4 Ly4BBL66 P0BkBiPiiP6iLBPwg0RRw22myNPN2gP 2P42 N0ik2Pi2R2R LPPw0g4gPkkNiw4LRPmkLP6 RgPk2Ri6B6m4640 ywPg yL kBwmiw4mNkk4yw6mLR0k4m4y2B RkgkN6BiyL620w N","c_data2":"Ri P6gmmNL i4yNwkNN6k gkmmP0BwBRg62 gikyB26wPN24w4L k6mkgw6LwPg0Pwg0i22B46N P BkwyLm 460wB04P m0iBy66PL40i6yBRLkRi4L6kkmiiyNigk0yPwm B4B40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":6,"c_w_id":1,"c_first":"2iPP2iwyNPg","c_middle":"OE","c_last":"BARBARESE","c_street_1":"02RBm6B2k6RNRk","c_street_2":"PL6ykLkPg0","c_city":"k R6BiyRyP6w R6R","c_state":"mm","c_zip":"290311111","c_phone":"186-281-2915","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3701,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BwyPw6mkByw mNPPPiNki6BLgLk0LLRm44i0yLLg RRNB mR4kN06Bi4mgPgiN6kNymk0y40mkm0kBL2N2mNLLggikRPwmP40By06imLLR6L02g2mPRBk2ykiP02BLgi LPB L0B N0wkL2LykLiBBPgP2g6mRBwimyLLBRRwymPgLiw0NNm4m46w2gy26wywPmL026wykN0BR4RmBi6gLk20wNm4P4LgkNwmB2B 6NyN Li4NL0g 6B2","c_data2":" NwRB 6NgP LmgRyg0gky6LNiNyRRkRm4PkLR24i ygL0 0wB2 N4P420LPN6LB iPi4P6B04g0Rk BiB0kBikm0Rw0iBkRNRBBiik4BkwP6mkL2BPiNRN6y4ywN4RN0i wk2RgykPw0 gBPNmkmL2R2kN20kyBBNRyi0iPB66w ykikigPBB0wB6PP NBii22kgN4LP2w LLBkiPmki m6NkB4 mLyw NN6 PLk iyPN006BN0m44BBP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":7,"c_w_id":1,"c_first":"iyygBywiwBwy","c_middle":"OE","c_last":"BARBARESE","c_street_1":"P4Lkm6gywiyLyy","c_street_2":"kkLB 42N4BggRy4Pk0B","c_city":"k2yLPP R iwNBR2","c_state":"gm","c_zip":"722311111","c_phone":"602-453-6077","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2924,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"02RPkgN0P0R0NLR0gLPBkwky02 ByPB4wyyBRikRmykmm m y0m42PiBmNym mw6By06myRLLRiL6BmBmBwLRB6LL2kNB4L0 0myL640i0yg0kmi420L4NBNyww2y22NNk000RL0gwgm 0m4yww LwmLy iPwy2wmgi02PyN0 RB0ywg 226miBPwm44PgLwygPR4L4kk6 gmm6 4g6BiLmP4imR0BBwk0yBR ygB46 2LNimiimi 6R04","c_data2":"R0mwL4ig6Pmy0mi44w4PkBy6wP4N0m4 g4B B60Bg0BwNmB PikL20w44BLgRRBm wP620Lw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":8,"c_w_id":1,"c_first":"NyLBiyyw2y","c_middle":"OE","c_last":"BARBARESE","c_street_1":"gP4Rwk6w4g22k26","c_street_2":"2B2 L0wwNmBg PwRNBkP","c_city":"Big igy RyLR","c_state":"40","c_zip":"079311111","c_phone":"702-728-7110","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3836,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PLgmN RPyk4RwPwikR2 2B6BPBP4P0mLg06wkiyg6N0PiNBR4k42LNi0N6yL6ikBB2ym RBy2kPBmB0iB 6B4ky2wR0Rm4BPgy2BiwLw4BB6RPgw0PgwgB0kwy04R2i6iPgm m6R2yRk6yN P2y2kyRLi42Ri0 NPLkwwkk4gB622wRNN42kkk6PLB0L6BBPkg0kgwgm kLB i22m0L0L w4 0BiBP RRi0wyRm2wym2Lm6PgwN62mNim","c_data2":"R4k2 gLmRgLLPP R244 2Lyw2mkiP0k0RPym2g0Bg Pigky2BNNR kkw04yNNNmN22g0w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":9,"c_w_id":1,"c_first":" mmk044ikNPky0","c_middle":"OE","c_last":"BARBARESE","c_street_1":"Nmkmim4R0L kgkk 6","c_street_2":"y4g66iNgmwBkP","c_city":"R4BB0BPgPygkgmP0wk","c_state":"wL","c_zip":"554111111","c_phone":"939-368-9959","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4241,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" w6mLki0wkkmB2B kk6i6k N w0R 4gRi04Rw g64y 2wL6ByiLRymNiw6wNwk2gBBBwNkwB44PNN4gwgkNBkw62466N4B4NB2PyRLkRy0m460y2w2g0RPN26igNmR42gwPRL4NwwPyLR0wk2kigykwN0PRmN4NkP0g0R6ByBNwkmw6img0i2ii0Nm2R RR6 g4 0BL LNwNNyB6yPP0i0Lm6gNNRwBNmym6Lmik i204w6gPBPL0NLNmB","c_data2":"wL6i2LmP2NBPk NkmwmkyLRimPR06igmkPRB0mLNP2wBBLkgP4 yigRm 40iRPPgL6 PkNk02N46g0w2Lmw4P N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081164,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":10,"c_w_id":1,"c_first":"wNP6R4ym 0","c_middle":"OE","c_last":"BARBARESE","c_street_1":"0PLB2g iLkRw4kg4i2L","c_street_2":"2PPkg0y4B g6i","c_city":"0LwNky2wkkyRRi","c_state":"L6","c_zip":"580511111","c_phone":"848-858-6621","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0086,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"P0wLN0k0gwwLg wkgggy4ygwLkN2P44BiLRPN02yBwL 06PR6046w40yBgi0BkN iBwgm6LgiB mmP02y2gRwy2w0iy2BNyk42LiPPPiy04ikyNwBg22ggP02 B LBwi60mmkw 0Lii2ggmLLiLwg R40gmwLPNL2BRPBk N0kymy4BiNkP mg2Nk LN0B6yRkNw0 iigLk6w N4Nk2NPB w64g2Py40i6Rg0PLyiNmkPiwLmB4kgm0wL","c_data2":"wg g NLw wii4mkyi2RBB4BLkL0Li62LNP2Ni4k246BNm6kw6kgRmimBkg2w0PPm imPwRywwL204wBL0L yRmm kBBiwgmRBgByLg6Rww"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081165,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081165,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":2,"c_w_id":1,"c_first":"4k 2my4k kgRwN","c_middle":"OE","c_last":"BARBARANTI","c_street_1":" 0w0i04NP y44LgN6","c_street_2":"4m0 Lk00i N2R m60","c_city":"i6By BL wmk R","c_state":"By","c_zip":"185511111","c_phone":"228-534-4528","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4959,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"4g0gPy0R4yP0yy2ik0w iRRNmLP0N60iPgLwLBLm00wNkBk y2myymm mi60kPLN6iPRPi6kk2PB k Nm0R4Nig62BymkgPy6P4 6mkmimRN BN4k2kw0g4m0mg4g4B4kwm miiiP0RgwR2N6BmPRLkmN2LPPNk22L6NmLL4i6N4gBBgw0BBRim6BNL6yNLL6wm6kBN4wPN6wgPPym0g0N6wLgkigyBmwB0460 BmBmyPNyywB2i6 yN6y","c_data2":"Ni4yPR yym2gLww02y4ywBPL0g 2 im60LP P404kR2PBikPywRByg 0NL iBkLyg00262 R4Ngy2kR0RBwm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081165,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081165,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":4,"c_w_id":1,"c_first":"4i262w6g mgBi2","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"06yik2g4PkNiLig","c_street_2":" Lg4B40BL0440m","c_city":"PgN2y 422Lw gP","c_state":"6R","c_zip":"728711111","c_phone":"714-875-8566","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3706,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"mBgg6R0ymRwyNy02g wyP6BmPmByBwL0Bikiw2LR4ig6yB0m0NiP0k6LBw44P6yP6PRwgy46iR gBN0N kk6g22Pg464k 0Nyiwk0mii0ki6 kg0gkkkiNRgiR4k2iiimRw42Nk4g6462 62mm gwNygmmP2BB4 m wB y62i0 4 4 i2LR4wPL022 4RLNm2gikii0kygiNgN 6k0y2P4 imw2yLP0mkii2w660 2R0RykRRmLBmm44","c_data2":"Rm66LmkLk6wiNm 0Rk6ykwmyNy mBki0Bi6g2kk64Bmky BygL w0By iBRgPNP4y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081165,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":5,"c_w_id":1,"c_first":"RBL6Lk4imiRL40gi","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"i0k6wyi 6i4Ny24B","c_street_2":"y6kN22iik22BL","c_city":"46R4Rg PBBw","c_state":"44","c_zip":"446311111","c_phone":"207-246-2175","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.173,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" yik2kiP06g64Bk6w 24m6yk ywyyiN46kN22BiPP 204kgiwyi gkw2Pw BLkwRy420wR kkPw6 Piyk2yPwRiwRmy gP BL2Bww wyiLLN2wP66g0i4yN0g4NRLB640NNyBwywN44RNRmyk kL 2PgRBPLNg0g y2LkwmB20kwkPkim22gL4kwki6R4 N24kyBPNkR wBw B6mymwNN40mi igwPLyLB0gRRPiBR2yBNk4m6ik4kR4i","c_data2":"NRNPBRNBw0iiRRNwP0mB 6RRy42iwkwNLg26iRkiyi2Ng2wBLg2R0N6RBk4PmPkLmmB4yky0yRiRmL06BiRmPRkw6026PNL6m4PiByw6g6P 2mNL0w0RigRmL6LRmRgL2wBNN64gBi6mN2iRkNP0PRgmwLB6L4giP2mNL6gPg6k642B0wigNLgkP4NiLLw6N6 gw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081165,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":2,"c_w_id":1,"c_first":"NNNmRw Rg","c_middle":"OE","c_last":"BARBAREING","c_street_1":"iwkP0gym40L","c_street_2":"wi6mwmk062i2w2P","c_city":"mw0R L0y 04Rwykmw","c_state":"i2","c_zip":"451711111","c_phone":"555-390-7199","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1694,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iNiwg24BR44m2g6 N2 m6 gP44NP4L6Lw2ywL mmygPymRBBk4wmRmRB44kRP4yiB4wNyiwi6L40BgLB4yikPkywRL0m2RmgP60iBRN0N2LyPN6wLLy2NRyk0w6P N40NmmggLRgyg44R4mmw2wR0RNR6wkiNg6wm0kmgRg0NmgNgy2 L0gNLyBm0iyiiw4B Bik04RNy2ywi24yi00i Bwy0wPBwP6k 4 ykgkLykL6ky NkR6ggiNwR","c_data2":"2RwLkLk2N 40gLmNPwgwkg04BRiPyw06iPRikRygBBg24Nkw2 RBLkwRyBPyw6g0wg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081165,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":6,"c_w_id":1,"c_first":"4igkk44 w6yN","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"2N0wwwwkB64PRP","c_street_2":"iP2Nkkwg B046BRBRB","c_city":"NRPB2B P 0BBw20yRN","c_state":"PP","c_zip":"633411111","c_phone":"746-634-7967","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1962,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"20NmgBmmRB 62 BL2By kg2L6P00PRPgmBRRPPBigLmiBPR20kwyiw0RP4y2RPB R6gRmNkNBPkNk2kRP m6B2mgB6iw4ki02i20kg00wm0k yymiRPNRiyg02kwRy PRmgwR6y6mwk4Ny0m gNR6RByNPR0w 4L4i06wm20gRkN y6ymP6igLP0Nii2BNPNLB RiBLBL2 02Rwkgkg2mgNm kkLPPwk6N0g2LRyLmimi 6L6wkL022gg","c_data2":"NyN 4 kNiLiyw26ywyBgwBy4m220NN0PPkwy4gN0w0RkLNm6 ym0gw0026w2y0k0BRgR2Ly6gik Ngm0RRyyggyL6BwmBBLByR2NwyPBkyBLy 66k0 PP6w6 20BB64R4gyN2BwPNB gmPm002Pk4yB6BLN0Ng4i00yPN 0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":7,"c_w_id":1,"c_first":" g0Rk 40Rkkg4w","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"0NPkR4gB6LiN4ig0B2Bw","c_street_2":"B6mRg6PRR0Bm","c_city":"RB424kgBw66L6","c_state":"R6","c_zip":"126611111","c_phone":"133-198-3531","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1983,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"02iwPB 2i2BB4yBgi622PRR4PwByNPNy0 m66Lwi2g0gLk LLNg6PP 26Nw0BB4y02i6wiNLBL2NmiNmi2N24y6N6Bm0 myPgy mg P0m6mN 4gy2w Pg6m0kR06iy4kgkN0g2Bygi6kPkkBRRP46P0Lwi6m PN2i4Ngy0N6R 2iNywmByBBPgiiRRyN06kPygN0PLNk42gygLy0gN 4kN40igPmgg62w62k0yLPLgm wB0g0ggBLNRkPg","c_data2":"gPPBg wk4w w6L imgP0iB4ggkyki gmw 6wNPPkgkNL20RiyR4k 6wB gBL20kPNN44LB2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":8,"c_w_id":1,"c_first":"mPmRmNiR4i4ki","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"kP4iPki226 6","c_street_2":"6gP0iN0B mgm 4gk","c_city":"ii LwN0gR2 kii","c_state":"ym","c_zip":"265211111","c_phone":"697-448-1546","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4229,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" L6BRwg N04ig4iywk0iBN0gLNm R0wNgg6BBy44m0PkPiB6 mLwkNP04w06wLwBNyyBw6mw ByNwkwm6BRm iP PNLL2 4BB6g4k4iRwLiy24BkiBNL6Nyy4LRg mR06m2g4BRLmy yL2m40PPkimN 4R44Lwyy 0BN4m gPLB2m20R0R20kLgkwNNN2PkmNBy4NPiw24Nk N066LyyLkm N y4iymL42g0L2ikyNmRNRNwgwmR0kmk","c_data2":"g4yLN22m4yk4mgPB6ki26gBPk022 0wikLPP6yi6kRk Bk kPw6mPm0B0 yww 2y4 2Pk6 wy6m N2i2 iR0BN Pk0Bm6kRBRiNN P0kwymgL m0BLBPNm k RPBik24LmmBR24ymw2wRiBkwy2wLRLgimy kB gmBByii4mR Nw244RLgwwiBwiLwk2kRBLwPNBNmw226PgB 26RNmN6 R yg6Pg6i26mm2N662ik P2PB6myNi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":9,"c_w_id":1,"c_first":"6wkg BiB40","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"gLPkm6406 L4wR2i","c_street_2":"igPBimPBwRwgiL","c_city":"gBBL gwyBy","c_state":"kw","c_zip":"340711111","c_phone":"912-627-2447","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.414,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kgwmw0gL0g0 PmgRP2RyyL0Ng4B64wyk6L6wLPRiN gyNmP6P mPw4y2mLgRy66BBN Pim6g6B02wgNRPmwywgi2mmL6mB244gw2N0y0BR60y6wwBL0ky0P0 4gyBikN20kBik4R00w gLwm 64LN6g w40 B4k4y2w46N Rm0Bk4NBw2PBg6kNy0m B24N4 NBBiwLNRww04kL2NikLN4NR40Ly6N6yRygN0myi4im wiPP02mPyLR2mw","c_data2":"wLRRg4P4Bw2PPiBmiLiRyRR6mNy2604 BBwN6yygy2w2Pm L4y0LyL26440LNN2ww2RNmwm P2y44mNBkkyR64R0BP RwNL0P2mmgLwk2kR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":10,"c_w_id":1,"c_first":"wmm6m iL k6i2 Rm","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"w 4ii4mw6k","c_street_2":"kk4m 2w4PRkyNkBm 04","c_city":"RLRPNP2i PiRmRyR","c_state":"yR","c_zip":"613311111","c_phone":"660-590-7617","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" 40PkBk mNB2gPmi0L2mkmgwLy0g2mPmRk0iPg2y4Lyy6gBR6Nwg0imPkRP k iy4BkNLkw R6RPL0L2Pw0g2gNg24k4w 6gmywiwkgyw2y402gLBkNmg P62L4024 wN0 BP 4 RRkgB646BBLBPR 6m2RBNmy2kNygLwRkkyLNB06 w40k4g6gR20BLk0yN2yBPgw y4PimwmkPk66wgm0LkPL0kgyN4gRiPPiLPgm04mmPPgwg4wP4","c_data2":"wNBNRLN ykm6 NNgkwyiwk44ky2 N42gm0wwN266y2miwN0gmB2LgB2240RPg0mNPm42L Ri4i g2iLyi yPk0N02gLLP yRLN6yk2NwyR0P4w2w2 4 yyL42yy w2w6NgNy0 6wPiwNBRmLRBB P 06gwmk0 4BmLk6gi2BwRm m0myLN24mi0m46yymNikByRiwBw4g02L0yLwPR4iwwLP yk6gk02y4R0kPR6 4Nm NwL6w26Nm4RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"BB","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":2,"c_w_id":1,"c_first":" Byw wRy202 L2L2","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"PLwNP2Nk4 NLk y","c_street_2":"mi0L46BBwLPPwm4m","c_city":"wPw2BP6RRkPk PBL42","c_state":"PL","c_zip":"018511111","c_phone":"517-371-7996","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1791,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2gg kiNP4gB2LmyB w4N2P4gR0gN0k 460BB0 ig64wkm2w4R R 64gmwmRwkky6NywBRgRwBi k4NR4g Rikgi4R4 6 RiLmP22i2i6yiBNk2gRmPwLm4w40ikkwkPk64RBk mB 46iPwNN2R0 k0wRwPm20426k4m4iBmRNNggB6Lwym00w4 2Rw g6BRB22gkggB6y RNw k0g2m0 0Pw4NmP6BRiiRL6mP6g6 m4NR0LByRy6RyN0","c_data2":"P0PP6y6g6NNL6PP 6 LLiiNg iP6P m 4LB RLL26BRmPNmmmL44P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081166,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":4,"c_w_id":1,"c_first":"2gPyLNik6PRiy","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"k wNykw m6gBkww","c_street_2":"kBwN6 y NiNB4PR 2","c_city":"N6yNyL6RmBgLkwRRw4","c_state":"B4","c_zip":"590711111","c_phone":"218-218-7646","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1122,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"ii0LBNg 66RLg02 LLP2yNL Pygk4P2wLPmRg40w04w4LRkmwPN04imiyLLwLyNkBNNm LP2g4iwm2ggBwi m20km 04P0m00220 04ygikLRN0446Rkg02PiiLRByN660NB N0 gN2R4iNRLi N mPgPNgy4Lk BPNByyi6BwNwN6PR wBgLPmykkPw6mg y6Ngwyi2 Nky2iPkLN2RyR 64Nk2igNwyk0k2 N4w6Pi R00gy6LBiyN","c_data2":" N NRB4wiPgk02P4mgwNkLN6BwPLk00BP2yg6BwLw2wNy6B2BLRyBRN2Ry42L y0i4ki46m26LPNNL0yiL2ywgLm02ig0R4Ryg0Bi0PygiLgk2 BikPPgigm RkNNwgmRk2LwmwBBm0R4yi6w2kNN4NN00 PwL ywym g2BB0L4NLN62w2226w260g6mPyRiNLPyii00gmL46y6gBmm2Ng4Pm yPPmik600wwLBwm 0B mikB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":5,"c_w_id":1,"c_first":"wg40P6wPwwBN","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"g0gi2NL4424","c_street_2":"y60iRiggR4N","c_city":"4NL6gywgN20 w4g4666","c_state":"L4","c_zip":"842711111","c_phone":"808-621-7085","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4748,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"22mm2wwLBmmiBikm0kymyBP w imwBNmgBLP06wg0 6BwBBB4imiB 0m04BR60P 02yP00P2BPL LgPNmgNwkggmBP0wwk6PyPm0LNwB4RL 0PLi2wwRR2NyLRBm0BkgggymNywNmgPP2N4PBky0mLB42B6iwN4kkwk2422PPk0k0NmgyBi L0RN Lmm PRm 6kw yg0kikw220PP Rm Lm 6LwLk2Biy2P4RmP4iLmPRLL24im6B2 w","c_data2":" ky 4 6gyy6Bm4ymiR0gimBPwkRmB6PwNi6BBw60NwNByL2B0w2PmBB P2mi6B6 y4 R6LN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":6,"c_w_id":1,"c_first":"ykmwm4mi4","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"iB 62L6kkBi i","c_street_2":"66LN 4N2 66w2","c_city":"w0wwBw2wPPLL0gi2","c_state":"RP","c_zip":"641311111","c_phone":"356-874-2301","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4188,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PBiiiP62g4mwggigkL yLR2yyN6kymiNm6Bi6w2BkkNmN46Pim4 kgmm 4 PBLggR0RgL2BNL 6yR0NigyyLB LgLkLkk6mN N k2 ggii66L kiyPm22y2R640NkBii4Ny4NBPkP62yw0m4kNRNigwigyPPBB2w6Lk0LLNBRL2wBPg02y2yy6LP240 RiBy440RgiywNg4k44kg R gRggP4R0y0gNmR2PggwL444w0yy040gwywR6P","c_data2":"LgmP 40Bwy2i4RRgk 0my6mgLi6LNP6Rm6LPLwkL64Rk4 0ywkNgmmL k Ry NBLB6NwyL2RwPmwk 2L0ggyNLgy iiLPw0ikP0LL4m20PkPgk00w2N60L0N42ykwwkBPBw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":7,"c_w_id":1,"c_first":"0R6mywkiyi","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"BNgii2wLwR4i66yPyikk","c_street_2":"LByk 0g4kPwNm","c_city":"wwB4wBNwgPgNwNP2","c_state":" R","c_zip":"767011111","c_phone":"875-882-8213","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4076,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6wgwm ygPP 2w6iwLLP042PBwy2wRRw iiBLk LwwPNBi2m0miym6g6PiPR2mkk04006L4iyP42P Nk2g6y4gig4m2220 mmL2gm0N2gNwRLwRgN4kPR6wkB4RNgk 0PLmgN0226 Nm yNg40i6wg2RmN2gR66mRRPN0Byy2LP4w4gw6N4LN42gN2k04gPiB 0m60mk 42N02mmRk igy4R6 6mRN4PBm w0m6PPi0P 4y yg0PLg0g","c_data2":"22i0PimiymP6 0BPNy2RPgwmwN0P6kByi wkyLwPm4RNN4kykwP0BykLym0Ry20Bmw62kky 0B6w 2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":8,"c_w_id":1,"c_first":"mwL g iwi NN0w22","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" RPmByi4PN mR mgm","c_street_2":"PN 2NPyB6i","c_city":"Lw2kykmRN2kgiR2P6w0R","c_state":"Bw","c_zip":"052511111","c_phone":"186-295-3252","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0209,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iRLR 2yLg2 k Pg666Bwg0 myg0L0yR4imiR0PR0LN4PLg6 iwgBRmPRRR4 4LB4B2Nkw4Ly0ggw2gLi4kii4mkR4NL4gR P LkPBwBgN0wR0wgiRm6i4iwNPBiPk64 g 0LRNRLPg P 6BPNy02RNBLy44RkimNB ygBk2NBwk4yL4yykyg4R6NPk0R4P4LP24RPL24mBN42R 2Bg0BkBg0602Rgy4N RLgB6wigmkLiL4NB6Lm26kiL","c_data2":"NiPNmRLBNBg4y4R6 iigm4Nwy2myP22Bi i0w gPP2RR22kwgR2P0R6w6wPNi i6PmPi6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":9,"c_w_id":1,"c_first":"4yBP2yLyP64Ly","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"i2BiPggNkPwR m2k6Ry","c_street_2":"Bim 0 Py4iN060y","c_city":"6mykmB4i6g6 Pm44m","c_state":"gP","c_zip":"488711111","c_phone":"959-374-5343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4765,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"yiRBgwLLRP4k6y44RLBLPiim4 wL2ymg0RLii20kLm6m46ygk2L6N4PLB6wL k4RLNky 6R2N26L 42446mgik2wwByLmm446 gyiPN0m02mP6Bg4NBm BL4ky6PNk0 g42kRPwi02Bg6migNBNi4BPy2k iww0iBBBmkLByyPmiw wL4 i2gkR00mk Li6NRLBR4iy Pi0BgkNiRRL6yNmyPNiBL4gy6 24k g6mg0B4R6mm20RLB2yw","c_data2":"0LPgL0mBB44k0RNgwiL 6 ByLwPLNmiP 4P00RmigmPikw64LRBByRi000i04m4BLi60y0kwL2yBki mg60 wiBNwL6g60LyN26B46"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":10,"c_w_id":1,"c_first":"BkRg g2wwP4iRRi","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"wiRyii0gmy2P6","c_street_2":"BL444 wRk 0L0ig","c_city":"0LiiPPwggy","c_state":"2N","c_zip":"998411111","c_phone":"415-587-9162","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.349,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"P 0NwNy NkP wmRN 66Lw020w4kgB2kL RLN LLPRRRL0wiBRPNyw wNkimm6Rww6BPRLRRiy0wLi6kR m RRwBPRNNNwNP0Pw4gLwN4P 60 g6mPR26wkwwNL PBRgwP6kwB BLLmL0BNi04L2k2224mN0yL4 4w06m4 g2w2Ri2N6m4yR PLy602gPiyRggw mLRk6miRyRwyyNkkRB6P0kw6L P 6mwPwRmRwB2NNgkkkL6mL 4m g","c_data2":"0iwNyPB2gyigByLw0L0wLLg2 R2RPk0y2giwPy gPLR6w4N6N2L446 wgw0m4kR6NRBBw 6B2R BR0RNiLyPRgwkmN0kBk g60Rw4L L 6L4y0RNgN 02246miLgB6 Ni2yR22k4wPm4mNgyg4kwN6LL6g2RPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":2,"c_w_id":1,"c_first":"igykgiwRwm2 P0NR","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Ny2Bgk0L4w6kmi6k 2L","c_street_2":"BPBgLm4w0k6Pwm2N","c_city":"Bgyigg02R06By","c_state":"2R","c_zip":"183911111","c_phone":"766-299-8660","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2827,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"yBLy6kwk4BNwN2km20R0 00PNPwRggiRR0g Lw kL4RiBk0LiNgm4y 226NLN0ByNw40 wgPB2266wRggLgBN44yw0 iigykPNNmyiRNk2k6g4gk4646mkLk04R06iy0PPR2Bi46 w4RNmL420RRgg4gkBi6NymR0g4 6ywyLBRiyk 4B4Ri42wi0mLPPgB 0k2NBBw Lmw2k4P0i2mPBy2P6imww0P6kRi64L2w PLL2ykk6g2kPiNwPB","c_data2":"6kR44PB BgN 6m N4yR22B6RP R2m2N4m26y gBNN4i0mLiB2g46 iL0mkR6Nwwm4L kNgP6B24P6 gmyNgNyP ygPgLB42LLm24RP mwk0i04BP6wyLB6PRki44LP44yi42006wkB0Ly64yLB2i2 w0kiyk24wmmk Pig0 0P0RPR2m0w4 L2Rm204wyR2wRg20iRL BB02LiywLmN4kR6L2N iR2Pk Lkk0L kkgk2i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":4,"c_w_id":1,"c_first":"iLykym2PyPNR4wR","c_middle":"OE","c_last":"BARBARATION","c_street_1":"g60RB BB222ii","c_street_2":" PyRkwgRR6 RPNyNm","c_city":"2P6wNkN24NgP","c_state":"Bw","c_zip":"718211111","c_phone":"912-655-1882","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2641,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"B4N2ig2BBywgBg ywiNLiwwLw66iw4NgPBkiRPB 6 wNiN yRBiRykB6BBN026NiwN igLNyRPRNyg20y4 PkkmP4wRyww0P0k2 B0RBgy gLg4R4iPkNy0mkiLwykRR6y 4R4g4ByNmw6iPimwBgmygLmgkymRk2kRkkkPL2mR4L0gLky2440LNR RPkPyBw w0kLLNL2yLNw2 y4yiP LLwN4Pg0L 6PL0Nwky2mw6g0RBgPR2yi2m","c_data2":"0yi 66PiNBP2LLmL04LB4ki0RLBy206kkyiwmgyPgywg6P20Bwy 0LNB0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081167,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":5,"c_w_id":1,"c_first":"iiwRgiiLRPg","c_middle":"OE","c_last":"BARBARATION","c_street_1":"k2B4g 40iyw22yi62P w","c_street_2":"LBNi0 N60y2 Lg","c_city":"L0B02yg L NByk0N400","c_state":"kB","c_zip":"315211111","c_phone":"736-825-9426","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3129,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PB6kRk2gNL0mwyk2gi0wyRwPPymkyyLRR NLmmwg6k BNP4PyNy0iL4wBNPmB6LkP iPywyy R LR 604RNgi mRR2mNym2 Riwgg4LB4NmyLkgmBk0y44wiky PwN46ii2ywiB2LwP4gwg0iP6BB0 y6P0ykRwg6wwN R2Ni 6Nyy2mkLyw LmgwN0gmPPBiy2y6Bgwy044gB0BmPkB4RRBLNk kwL0P0g6P26 RRk46R62B2yBiwBNN4","c_data2":"LPBLPB604Lyy yLyi2y6LBL R0yw NLwm BN4igRm 2R0P24kRiLm2yy60kg6ywNRgkmm224kmi 6kgg04B2 ky20gwPy2 yN4m Rgwk6P62m0iwL4m6yRmgiB602yk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":6,"c_w_id":1,"c_first":"Lm4Lky22","c_middle":"OE","c_last":"BARBARATION","c_street_1":"w2m2LiNN6miyg4","c_street_2":"26w40g wPRkg","c_city":"4my NmwPkR k4","c_state":"gk","c_zip":"051811111","c_phone":"666-926-6387","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1542,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"yy PRy0yNyNm0 RNL44k6Rm6w6m0 w RN mLgNikyk2PRm0B4Lkk0kNwwi2mLi2wNwL2iiB6LLNN06L6k PNR40L4PgPy6w 4iPL0BiNgNNiB60kkkNii4ykRy00w4kmmwm2PBRiPL2m Rg4kk2PwN4i2yi6 iRBmPyP66kw24gRNkBwBLRii6NNwgi2ikyLww4RNBRiRR2y2 B2LmP4RP2Lg2 wmkLBPB0666Rww yk2wBPB4gwB06w0k","c_data2":"N2g wN6gLNRmwP62iP20mgy0LR4y020RggR 44LRLiy64kLNNNmL B Rk0g6iyRmygyyN4gywNLBmyR00RywP gLBNLkB6m6B0Ni6kwR64Bi0y0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":7,"c_w_id":1,"c_first":"Ny BmL0P","c_middle":"OE","c_last":"BARBARATION","c_street_1":"P6iP24iPN0gRR","c_street_2":"gwkygki2m4RBR42 PB","c_city":"iL46NkiNPg0","c_state":"Rg","c_zip":"610911111","c_phone":"274-326-6928","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4628,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6Pmg y4ygyw RmR22wwBy0PmiRNm4LwB6PmgyimyRmR4LNiNPgLgmPk4 PRk4RkkmP6gRg4P6i g mNw2PBiLRNNgw2g040RR6wyL6 yN 2R6wBLi6LmkBRR m NLRkP2w64L6k6N0LB2 26wgwR2PR4R0g2mkP2m6LkmLi4iyR 64 4 kwg yw2L26wwB4kLwwg40PBkB2ig y Bw LRi0R6 L2Rm044BLPygRRm4600N044NRm6 4","c_data2":"wP0iPgPBBBR4NkLNBB6ByRw6kwPwyNPmmL gPLiL4iwNimgwL4RL6ykgw 2BL2LwN4y0wkk i6P2yNgLRwmyBgwkwwgPkww2PmNLNk4yRg i6i2PPN0k24 0iLN2Li4yRkimL6RyBLwBLL2k0m04mm0kLiygL6y6BRP0ykkRB6y0 2Bg0yyi0B02PwiR6ymmNig04kyLwPL kg 2gwPw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":8,"c_w_id":1,"c_first":"2N BL RL 04y","c_middle":"OE","c_last":"BARBARATION","c_street_1":"P6NN0g gPmL","c_street_2":"26 kwLwwP2y2662 PL","c_city":" yRR6 6iLB4LkB","c_state":" 6","c_zip":"617411111","c_phone":"474-558-2753","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2071,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" gN60RLkkRw2 k6gwR0mmwBwLLm0kPmyigPBB 0Ngigmiy64ywwwR64iyk06B Ng NN0Nky2mNgB42mwLmB0 L4 BwkmLmLLLmiyNyk2BR2kP2NwBRykwwi m gig w0wwm22060LiL2yRkgmL26iL4B0m04iL0NiLLw2y2kmPL mP2BPiygmNiiR0mNgRB24kBNRNyw0kB0PLmP4k4 BPk0PN4 iNLyk 6RimBgLgN6N gyRRRNLL6Nyi","c_data2":"k6mg4gB04ygyRRLBRg2RNRR64600LR2NPPmmNRkg600LLkP2w2Nm P04gyB 42NyLgg44 gRyikBwwwB6NRNNNkP 00LiR2N0gN0y4ygR0L4LN02iRikm60gP2kPiy2NyN NykBNPwk6 B6PB 44Ly4Ri0y2LgPg0Bi6ByRiNyN 2mNkgRm4wLP 0mwP4NBgiRBwLNgB4646NyN2gL4Py y yw2mk0iwy6240L0 02iNP46Pm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":9,"c_w_id":1,"c_first":"yPwBRm4RPBgmy","c_middle":"OE","c_last":"BARBARATION","c_street_1":"2 N0i2B4N6m4L6","c_street_2":"kP2kP6RB0i2LLk44w","c_city":"wBNy20gmNiLP kymBR0","c_state":"PR","c_zip":"822011111","c_phone":"121-143-7689","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0641,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"Pg6mRyRmywy w0w4wyB PPgBkwLkiRL4 kymgRN4k gBg kgmRk46g6N2gm BNN402NwgB4NPyiLw4LBmPk2NwLm PkPBRB RN6Ng0RNw m gmwBk0kPBkiPkR20RRLwNw0N2m6P wg ggiL462BPw2g2RRPPi4NimNy gmB 6yiP4R0LLmiP 2kiLiL4ww424i4m0RygykgByyN6P20wPiww46 N Ng0BwgBk0k2RB6PL4Pm2 PLyP0N","c_data2":"6NRiw6yL2 mRyPB26B04PLk4k wLNg 66 w6gkm6 L iBB2BiN2mR26mPRNgPP4R0gB0LRimN k2PL0NR k66ByLg2Ny2iN0 wB iP2g2R24im6LkkRw Pg 0mL4N2Lm4gm0RgiyRgL6Bg4P6kLww6wRB4PL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":10,"c_w_id":1,"c_first":" mB 40Bg0g","c_middle":"OE","c_last":"BARBARATION","c_street_1":"yg0kBgw6B0kyw6N","c_street_2":"igy2k0 RN40kBm mPiyg","c_city":"L06gN 6BBBLikkwg2mw2","c_state":"22","c_zip":"561411111","c_phone":"410-137-9683","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1955,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mmwgR 4k2g00gLwwyyiNig gNwggw wyPPRig2BigRi4yyyBgRN0Ry064LP6gkLiRBi wiP2m406m 24Nw4i0LR2NRgm gRmwikkmRyL2R4Lg06N BP4y LwyBy kmR426L4kkkg6iwm mwmBmNNPw 0NyNwRgRBiki6Pk2kRwP4NgN NPmNgm4mRiRkBmk2PNwNBNLNmBLg y2wk0w2PN6w6wNNkgL6N RyyyR2BBmLk6y2wyy06w","c_data2":"kwii4BPNP0Lmy0L6g20k2 kBk0 i0k024yBm4wwmNkPLL62mi04ygR2NPmRim0m4wNyB6NmgP2LRRN6Bm6N6PmmmmwLNLB4RmwNLL62BRLmLBP66Ny4k66gL4ik y0N4myiyPBw 0Pm0 R0imB6ikBg 004L0m0 kmm024mPw62yi2BPy ggm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wLimPN6miB6R2BBP46L4k0g2BgB64gmm2w4RmB0w6NNN4RLkPy2k0mNiy NNP 0 k0giN6m kiyig4 66y 4mg4BB 4wNm0w0i4mykwB4 0000 w4B2y46P4LBNPmLLRwPLykkNyB20ywRmPRmL6226yi00kg2y2w6ggL00kNmyg2Rw0y0gNy6LLigg ggii yk44iwiyyi0Rw6 wik 0gPN4mLPmPw4gkBmggL4k46 P0yBkNg 6R6i","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":4,"c_w_id":1,"c_first":"BPg0yLwRk","c_middle":"OE","c_last":"BARBAREING","c_street_1":"6wk0N64600 R","c_street_2":"06NRLP0Ryg y6NiR0","c_city":" wLm0 iPyNkmNPmwmB","c_state":"26","c_zip":"851511111","c_phone":"993-592-8926","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1559,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kwBB4B NB R24LRPg042BP4PiPRmygkLiwBiL4kyRgm0yg4L2y0gRmgL60By 40Rgg0RL mB0m6PR wR20Ngw6L 20mPB22Pk0LRN RNRByLLmL2 4mNNRiwk6Lk22kgy4Lwyi44 6BP4NLywPLmim2wwyigNL4NR44 LR4m0 yimggLPRkRiPmLmLBL0RmR2gw4wwggkmNN2RB6giL26Lk2RL60k0yk000wB6wNgB4y0i Nkw wBy4","c_data2":"P2LB BwB2kw LBN0kiRLBwLPwy02iym6wLwB2P kBwkmi igkwRRP0i4RyLLgNyBPw4PkB 4wwk6kRRRP062NR0BP2RBiBw 6g kky6 ky0Pw BBP yN 0mPkwk2imLmwBLBN2kww4LL0P0LBm6Ng0P4RBNim2yR2P44kiLgmmywNkmmRkPiPmww2mmiN LLwwByi 6m6RLPy6PB0 yBiPy6PRN22m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":5,"c_w_id":1,"c_first":"R6LPPm 4gP0N","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 40B0gNi20wBwL","c_street_2":"00RByL6Ry2ykgLP26","c_city":"2LNk2iRRN0yBw","c_state":"i6","c_zip":"359611111","c_phone":"909-504-3037","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3982,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kiky 6w6i iNL06 6NPiBmgk2 2 BBkLRyk4w0R ywwkm04R4kmRgRRkRiB4gBi0m6mRmPPmwkRLmB2 kBkBP2mLPNkN ygLw 0m0mwP0y20Nmm4m6mmL0g00N4RkwNimPNm60kBk4Nw02iBPmywL 4gLg4PL44w gNP 6gkkmPm kR2w4 m44kRL6gkB LgR4 RB RBLN6 N6iwN42wR6kmkRBLgwRwyBNm6Pi4iBRN40Pm0Py262mkR","c_data2":"0kBy0i km RRPgRkNm6yPL04 k42g mki64kBNLw0P2y42202gm0RNkg2B4BPmBPB4L0im2w420Ny gmL 2 imNyB6gkkL0N4ByB PLmgymw0RLmwik0BNyiR06g242L6gN62k2wmPgR6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081168,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081168,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":6,"c_w_id":1,"c_first":"LB NPR 0","c_middle":"OE","c_last":"BARBAREING","c_street_1":"44gwPwBmiwBiim04wmyg","c_street_2":"yLwByPg2mRgB20mwi","c_city":"yLk444 LB Rk 222BL","c_state":"4w","c_zip":"013811111","c_phone":"910-889-6085","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4218,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iL24N6N0 gkg4kk6k46B66LRwNPBy4PywywL2g4BkN yg0RiLy42yyLLPiPN0LLRkBPkLPkBPNyi6PNBNRBm4kLwNyRmymm2g4R2wBgwPyPRg624m4gi4gN 4BLPB4kyLmiy2BwPBm2gNgw RwwPNRLkiwLNi yBkyP466my2w mmwiiigBRRwikL2 2BPRkmggwmR2Pi0PNNmyLRPwR60ky20P060kBLgmmBmgRRLkPL0N20ByPP2wi06","c_data2":"2 wP00P iR6g2RwRkw ym2mN2RBkimw6Lm22RmLwNRwm44ykPgwkBB0i44w2262i0giNPkPN6g gNw4Bmw6yiy6mw4ywmR0k mP RyPPwPgymikB0wkByPB kR4ywiP2Bii4gy0m y00 62yygRNLiy2wR2k6wPkw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081169,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081169,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":7,"c_w_id":1,"c_first":" PiwN6LP6R4giP","c_middle":"OE","c_last":"BARBAREING","c_street_1":"yy0wgN 0BwLB","c_street_2":"2 P0y4RN0B","c_city":"26PP6i0y20yiP4PLmNyP","c_state":"P","c_zip":"767011111","c_phone":"897-842-8196","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.0914,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PNNgm00P6Rkwi6PgBgmP6mLB6wmL6wwkNk2BmLRwi46w4imRBmLL LL0Niw6y0kR6PmPR kLN4gm 0wN0k0g4k4ywm66 wLNByw62mwi2gw B04iPLm2N2myNig m6R6Lw4wP2PNPP R06P0NP62ki4NLN2wBk6g yLmNRm 4imLy60 4Ng4 4L00 mky 4wg220 2kkP0y yi P0 RwL wmRwLL0NkBwiP miy6RR2i P6P44wNB4mi2","c_data2":"26gBmwwm0iLN2w6BiP6wyywBPPR024L4g2Li4imy iRNRNLgLyPPy y R0gkkm6Rwy6iP2w42i Lg4Ny464iLR6ww0w BiL24RBB0igL0ki4m6i6kg4kyy ii4P 60wgwR6yk202gB02yRN4wNR 0i226mN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081169,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081169,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":8,"c_w_id":1,"c_first":"Bw 2B6k2km4w0BN","c_middle":"OE","c_last":"BARBAREING","c_street_1":"40i 444Liy0B4RL02","c_street_2":"2N246 wBiw 4RNwN04","c_city":"LB262yPP6k B244k4Lw","c_state":"y6","c_zip":"034111111","c_phone":"393-447-7498","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1812,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPN4Bw6N wBgw4w6iP0kw4BwggP240iywRR L4yBLi4Rw2P6m NN R00L2giBLPRBR60RRk2y6NBRPw6Ri4NLi20NwgBNBm 4 g y0P4wkLPwNmwwgkB0P4y2m Lg6igPmL26 wyN0iwkRg4i P4wi6 BRBNgNBgmRBkB2gP 0RkgkwkiP w4wkLiRPyiLgyw2gRg44BR2w2kNPNRN4ByPwg046w0R6g04ykP m0gBBiB0iwyP ggRi4N","c_data2":"2RPiP BymmN4w4R0w22gwgiBN4gg4LLgL2 y6RBwB62R RLLiL0N4ywB02gRLmiy0BL2wm4kP4LRyR0LBwm00BNi26Ng4yB BNgiB2 mRkywyBy6i2ymN0RL0Bi6kg2kk kgR4BNPwN yNgPBk 4wRPN24Bm RLmNR6k2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081169,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081169,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":9,"c_w_id":1,"c_first":"BiB yLwP6myRN0k0","c_middle":"OE","c_last":"BARBAREING","c_street_1":"kk0P2BPiiykm0 66N0N","c_street_2":"iR4L kN60R2Nm6w4","c_city":"Big2iNkBgmkLPk","c_state":"iy","c_zip":"454211111","c_phone":"429-210-3089","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2704,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6RB4gyRi2ykwBy02R46i ymLLgygi2N62Bigg0NwBNyNBLy0i6wPm0ymN6LmyR RiwL4kPP6m4k y4NL24RNB4mwBk R2 0g42kR600 B0yig NgLkg4PwyB2B6ygg m24gmBi4NNykP6NR 2gR 2wgwNwL4LN624NLLk2mkkwyyygm R0PN4 04mg4P0 mLk26i0RNkPgB4P66y6wy4yBRP4g0BBR40y6RyLg4 ygim22RP0yy0Rgyw","c_data2":"40k R 2 RkmBLmLPLw4NP224i6iN g240gNkL0mPRkgRPym6Pmkkg NwkkNy6 24kg4mPBN2k662L2Pmm0664kN N iRg0mi0k gikNwPwB Lmiw2y62LRmRP4Lm gkiLN4B40kgi6mmL0kLg4w60y6 6yPR6iRyR4mg4R2gLLLwiPRNRLR222 kkRLg4Byym4g4Ri4NR20kykLByyNPPLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081169,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081169,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":10,"c_w_id":1,"c_first":"RwL0wPBP","c_middle":"OE","c_last":"BARBAREING","c_street_1":"P0wwwPgPwPPmkywL","c_street_2":"2iw2i6Lwy0ig4m040L","c_city":"mg6w wLk y6kPg4","c_state":"g","c_zip":"139611111","c_phone":"226-288-4631","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1072,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"B266gN4LigPRy66wiPLkkRiN2PLPmgk2Pi0wP4iwRNg62N2NmN262mBBm PgNLP62g2PwBBmPg4ym66NN4kLRLggRN6wyBwP4N2PPw44Bm mPNmBNgi0wg6g NNiyLPRgPmwNNgLmB6kNm24gLB6gN244g NRPPP0iw2B44 Rmw42LN402wRR0BN2ykkk004i ymNmBm yBBLkPP w0PiwRy 60BRLRgwRLk04m2w0L 4i2PL24myRgB","c_data2":"0RwRB NgyLRgP4P 4i66PL266LNPPPgN2i6RPkk6P6iiykwNkR646i642 2k02kL6Pg4y6PBi4L2wNgyNymkwki0LP0mPmyNgN2imkBygB6wmLw2yyPy4PB2iN0L2iy42kNPN 0wiPmiRwgw2wgkg0BBPNPLi0NB R6B0L2iyk 2PiPgwwwimBNRP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081169,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"customer","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081169,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"after":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":-9.58,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24396864\"]","schema":"public","table":"customer","txId":1325,"lsn":24396864,"xmin":null},"op":"u","ts_ms":1664141081517,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"after":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":-9.58,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24412664\"]","schema":"public","table":"customer","txId":1326,"lsn":24412664,"xmin":null},"op":"u","ts_ms":1664141081521,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"BB","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"after":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"BB","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":-9.58,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24432392\"]","schema":"public","table":"customer","txId":1327,"lsn":24432392,"xmin":null},"op":"u","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"after":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-9.58,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24452544\"]","schema":"public","table":"customer","txId":1328,"lsn":24452544,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"after":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-9.58,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24463576\"]","schema":"public","table":"customer","txId":1329,"lsn":24463576,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":1,"c_w_id":1,"c_first":"2 4Py0Rg","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"PwR0ymwiRN0m2","c_street_2":"B60g4NwRNw6kLy","c_city":"04y2 miNRw0y4Nki","c_state":"22","c_zip":"093011111","c_phone":"490-950-6869","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3173,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6ymmkmwyLPiN66RRyggLy m4gm6N0g0wRBwiw4NwNywN RP66yPiiLi4P6B46BB2m giLw4gB22w6PmLkLyRkk0N0mikNmg0m6Ly4mgN0P2NkgPy wwNmkkLP6g6y LPBB4P2giiw4immRikNR6w0LLRm0NwP6NP6i6gy4i0P4wB6P4By PmiiPNBL0y0 L R220Bykg2 N4wL iwm66Ng4g2yR6iy02LyBy6Ng22RwRyP L0iLmwwkL","c_data2":"LPyPmg2gwg Ri4ikBB4B242LBmL2RP4BRg6i6BkkR L4 0B6Pw0R6BBP04m0ig4k6yBkLyL 2PNy immkNiwRm4Ry4m6B y2R2gLmmBi wNLwi6Pi0RkR00wg 6yk40N20PB R4iiwBkw4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739147,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739150,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":2,"c_w_id":1,"c_first":"2RiLNwkk0","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"iL04 gL6NP2k","c_street_2":"02RL0RwkRwi46giLw","c_city":"mNkPPyBymii","c_state":"6B","c_zip":"927511111","c_phone":"208-324-6621","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2Bim6PPL 2P6iLi6 NigB 6wymBR0mP gN4kiggNPNLgyi22wR644BB6PyBNL Pi0wPiRLRiwRw6 yw0B Bki0NNg06iRwyBwg6NgR 4iR64y46Ly4wgR20gw2RNw PNL2yk42w 440P 0 Bgi2Ng ky4BB62g 0Ri4BiB2 46kN0kiLP0iiy0BPB20R66R6yN62LwBR0yNiL6yB04gPgRPPiBRw BiiN2 kRg2RikLigm6wL2g4PmB2L","c_data2":"6Pg4wRkmPR06NB0iRw60LmN6 0 gLm2 22mB wBPNmk0ygRw00NR4yw2gwNyBgLLP mRRBP20PByk4ywBP0RP6g24ki m20ikigi2NNL2P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739152,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739152,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739153,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739153,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":4,"c_w_id":1,"c_first":"gg4P6N RNLw kw k","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"kB4gg6 N2iN","c_street_2":"P24yBBgyNim","c_city":"Bi22y22wkBB","c_state":"wg","c_zip":"434611111","c_phone":"708-713-2028","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2625,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gBmwyiB226kw4PP 4Lk2L2Big64kg2 R402w2i4yBggPLg0wP4wm4yR6RRk6mwm64iyBBBg2kmyLyL4RRBLkiNRy4yPPw6 4ikk2wm60 4RNBLP4R mm44L0w6N 4g kymB6gB RBLLk6gNP6 wmPiN4gkN6N22LyNmRwR2N6Pw64wi4igwmiRN402yR0RNkBiRN0kk mm6ggiRimmk6w206RikyygL4m6 Rk0P4L226PNiwk4 mkP2062","c_data2":"g2PLwB mLN24NgLN0RmgNky4RNLNyBkk ywPPm N0wNN2wBNgmP26km20 L4ggmLgmN4R66RB40gLyBRyP2m46B2gi4mBRwB2 BPkNLm4N PNPy4g4i6N4g20PLm2LNwwwmR6 mL0w22LwBNB64mL0y4w0iB4066Rgi g kg2 g00kNg02giP6wN6 4igiLmwk44PB6NPR6iPRBBRR4kiyN6NPy6g2BPy y0N4R62y0m2BiL6L4y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739153,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739153,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":5,"c_w_id":1,"c_first":"2i k 4gN2k B0","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"gN2gPiwgyk","c_street_2":"m0w2P4y0mgPw64","c_city":"wykB 0kgw","c_state":"Ry","c_zip":"628911111","c_phone":"139-894-5975","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4989,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R RwP 2wk6mN0i6wiNR24yRRP LPkmm42k0iLNR62mNRi 4BNRyR4NkPPgm2yL20y4gigkk2020L24Rmkig2L2NLky242L4ywPiwk 66k0g4wBmyPkRPmBg gi2k64g40m2Bgw6gwL 0kRkBByP2gm N42L0wB 6ykkmi2PNR0R6 B2B4PRBmL2w0RgwgmLyk2w gRyL PNLw4m64 kRmm2NPNNLNg w4w0ykBRkkk0Liigkw2mmR4miyw","c_data2":"wgNm4Pmmy6iP0L6mykmm wNRLiiR2gL0NyNPL62B 0w4my4 PN6gBwkm42Rg6RkNk4m LR mwg4B6mki6Pmg42P40Li4L4LmkN22NBNRPkBgLN mk0 60 N4ywR4N04my0PBwkLiBwwgL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739153,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739153,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":6,"c_w_id":1,"c_first":"P4PB2kyy","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"4wi B26Nk4L2","c_street_2":"PPBkwgBiPLBLRyB6mPB","c_city":"PgmRgmgB4P20","c_state":"ki","c_zip":"465111111","c_phone":"220-874-4078","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4935,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"44k2wm RykgRmk 0y w4Ry6w4N2BmB6gwk 04BBiL2LgBLimkmm0gk0yy2RL2y2N iBLPRNii2PN242LBiiL0L0B64NBwN yBL6 gm6ByBN2gNimm2ygBikm wy4P6yk RP0wBBgg6B4iLLLi2PmRyPwR m4mBykw4NBg6B6yL6N2BBkBR0LkBBwgN 20wBi2gyP4k0kgy P4PmB40g0B 2LwLBgBR4kN 6B2RwL4ykg6 4wP4NRwgy0gN","c_data2":"ymBm4 wwP y4BLRN0 i m 2 mRLiyLR42 0Pk6Pgk64wmggRN446kB4BRR wPwkgyPi N4yN2NkR2L44P 2m 6462yw mNRgPyw mk6y40Pykk2wimyLyN00Bw0wigL R0Lkk2w06B mwN40ww20BBR 4wRk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739153,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739153,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":7,"c_w_id":1,"c_first":"2BB0BB6LN2k","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"N42gLmkLBPg","c_street_2":"60myPRRgig4N 0 2w","c_city":"LN y4RPw4Ly 6w","c_state":"Lw","c_zip":"956311111","c_phone":"799-822-1590","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3341,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LmRigwwBy2ig24 RgiLNm26026mPB64wL0Lm P06w6gg w4N0wBB0g00B4Li2iky2wLL NB 4Lmmy46g 00PmRNygg4iwNkBkR4g6y22Rg4062iwRi4wLygNPNBBwPPgy24 y6kyyg006LPw0R 0L4L2BL42046L0BRg2wRgy4imNRLRkNB6N2wgNkyB0m22wiPNPkg2wk66g2PR kgymP2BwiB06mkg2 NkPkiRBy2imy4PRgNkB4440P","c_data2":"RR6RRyi6yi6LP mmmL222kg46iBg46k0N0B66g2gRRBgy6iNB6RN2m6kkikRmBLkygNkN0g0 4404iP6w2B2B2wkBi66L 6R62NPNyiwkwRBkg02 NBB2B2wm0Ly422gm0gmL0i4myg02B2k4mw0y0Ny0B6 kRy mBigg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739154,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739154,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":8,"c_w_id":1,"c_first":"400N 6gBR0yNkR4","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"gkyg4w wBmymNPi","c_street_2":"gk0LwBg0kP4NBNPm","c_city":"6kyP2iB Rym0kmPN 2","c_state":"mi","c_zip":"709911111","c_phone":"868-574-3700","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0829,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"y P N64BkkkBkm N kmi0 LLy wiN4imm64PgPm0Lg2mwP4m4LRy4wwgP6624NPky0wm4 wgkmgBy2g LLNRmB0wgRLyLB00w4Lkkk6w2mNkkP40mw6NLg400iNywwL ki4LNky0gi464yNg2imy4ygwkgPi6m0 6y6B0ikNRmLmmw6w 62wgi 064Rwgw4myNLygNRLBB 0 mN6B0LmBRk6PLN622iy6BwPLgL6kwPLPRiL mkm RwR","c_data2":"B Pwm4mPRLi2N6 BP6R iy4P iNmwi0BNLgRPLgw40LiwymL0mmBRkw0RBBw406i6BgR4i iw0kN4ky4Lyy00yyB66g0iyLiLPmgy6gRRiBP44 wNRwP24Lm6kiyP6NBLBkkB4P2 6my 60kmRB6L iLgyw0Rwmiww26NyNRB0 4iL0w00NL iBik2yL0ym6B0PBLymgN02BN4L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739154,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739154,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":9,"c_w_id":1,"c_first":"R0yiRik kwP24","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"N40BiR 0 0kBygkPBm","c_street_2":"kLk2LmB yBkP","c_city":"mRRPPR4 k2L","c_state":"6L","c_zip":"497811111","c_phone":"552-389-2881","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4114,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6RLy44yLL2kPwkLy2gymRLyPkmgw202B6w042R440 yR6yLmiPw6yi4iBNmm2gg4i0iiBR2wi2gy462wN0gBwwiy my20gL0Rw4RykL02g2 kNRm4y6PNigmy6gg226Lwi4iyyN0PP44m060PPPRL2Ri0Ni yiRN266 2RkmkmBN2 4RkykP4gRkBwNRRiyP gBiw6y6k0wNRg2RNBB i Nw0B0Li iLRPyPyy0R0kBwPyLk4 i44R62yw","c_data2":"N4R0wLNk miiB0N2giN6mB2gNyRLNL2LBBBN2B20NBB6iyk m4mm6PNgNN4 226kwN6gy0y NLLwR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739154,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739154,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":1,"c_d_id":10,"c_w_id":1,"c_first":"wPmBgmgNiP0 64B","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"wNNmkkB0Lw","c_street_2":"gPRwyk4Nmm62i","c_city":"2RLPNg24i204 2","c_state":"0P","c_zip":"663311111","c_phone":"116-402-5438","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0339,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NNmPNPiywwBiiw60LwL4yRmP4gwiwLL4w4NP 2 NyggRkwikBN k wRkiPB0iNmwR4L mRk0w6w4kPRm4wm2i00w00m40N02kwgLLwRLwi2BkNyB0L20g0y2LmgB0i4yywL0 BL Lmi6k 6mm4g 2y 6RRww6mRi2kBm2g NkBN4 22 wPkmymigwymLPkwm6PNwwm26N46L46gmmyyBLkmLkLyLN2BiRRi0L4R2ywNmkNNLi4B26k2N0m","c_data2":"gLLyykmw2LkNPPkN44gkwwP NL42P6mw0BR2PNgyPRi2060P0PPNR 2iyL2i0mRN24kmiNm420kkyPNw4Rmmm2kgwyw46gwwik2gymLmLwgk0R0ig6L4N www 6L2wNBBB0gBigB BN BBL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739154,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739155,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":1,"c_w_id":1,"c_first":"gP22PmwB2mgkBBw","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"gygPLL6BkBPNm0y","c_street_2":"LLm2 2RByRRmRyy4","c_city":"Bw4Lkm404k2L","c_state":"NL","c_zip":"610411111","c_phone":"548-579-5258","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2789,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LgB RL6g0yNRmLw Rkwi NLPgmmk 62 mwygLg4yNNiNL N4Lyi00RkB0yg44ygmL0Lk4 R44myikNBw yRg mgk PBi2604mg2kL6gymgwBNkB w LwkN0wy0my0L20 B64yikLkL yy0PL4i4P0RwiBi y4Rggkww6i00y2yLR2mNBP6yk P w0B4 PyB L6 N42gR2RNiyiyL 6wwgNymBiyik2P Lkig 6k4wk04R0Nm0iLy6m04","c_data2":"gk4 iyR4wyN0L k2NmP 4L0mN0LP0N4gwB4PLNP04wRNkL400Bykky4 6g6gNw26R4PNw6N4iw6RigyBB4 R mwNw k0m2PNkLRyNw4 Ng0NPR62yBL42RBNLy0L40 g gyBii6RR4igRBw6gB6BLy4 2N0wiy4kPi2w0gLLNwkR20L y0wkkwy62imR2iik066 LNy R06mLNPyRRwkNyigmByLLLPmRPgL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739155,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739155,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":2,"c_w_id":1,"c_first":"LmgLmgw0i0 L0R0k","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"L4iyRymNwNPm2","c_street_2":"0RNBy4yBk 6LL0i6g y","c_city":"gR60mmLNR22NLLw","c_state":"km","c_zip":"127611111","c_phone":"706-741-9824","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.117,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"km0wBk6RRim4yPwPg0m6PRkRP4myLgkRB4i0 g6 yRi2BiN2i gL02kykLigiimRyP 6LB44wBRmBw2Pm 6224Rw4mLBikNP k26PiPN6wRNwRywByP0iBi22ikPwyiP602mLN00i66 PNBikB2 NN4w0PB0iBwLLRBwmikyP0NNy wB 4Bkw4mBykLg 440wgPi024006ymkyRByyLLiimyi6PmNiigNm04i246RNk gLPNNBi46B2P","c_data2":"BwB0LRwm4 yPimg 6kN2 i w2B k6R0 im6iNL6R0iwymyP4 RyLmiLNB4Pi6L4kwiPmwNgwm2i6m40RLi4i4BkRykywm2mmiwwLRmB4Ng0gPkwgLk0 0w0mB4wm km2mN2Rg2L B6646kN2RPBwg4m4N6B i yigRPw2Liw2gB4 L m4ygk B P4BPiy06y02LgB4kBRk04LN4N4gyR4wRP62RRR Pky0m2gyykmm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739155,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739155,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739155,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739155,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":4,"c_w_id":1,"c_first":"LBg6 RPggB","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"Bi2 2kRgk","c_street_2":"i g0Ri 4PPym","c_city":"yN0kRRyki0R4B","c_state":"w0","c_zip":"457411111","c_phone":"281-912-6413","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0899,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g00m0Nw6RygRyw0RB4kyB4BNkiLwkBP404R6m0NB 46B6B0wi6Bk4BNNmLL2w4mywPw4BRkByBiBB46Nwk4wgkmP6yNm6wyLNyLmi2wwwBRR2yLB4m0NLNN0 m m0i2y6 g NL 6yi2 N0R0yN0N66PmPg0L2iP4N4 i m4w6mB02kNiPNBLm B46BiPkP2 m60y0N6Py4k44m6L0i202RNmLRN P22B04PmmiPkwiBmkNPNNmBRR w0","c_data2":"R6PB2gN BiPNmi04wgN060N2 LPiRPwL4iPPy Rmim6g2 6gk2i60LLPi6yk 0R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739155,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739155,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":5,"c_w_id":1,"c_first":"Ny 00LPiy6R4RiP2","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"y BkNwRiL6w4y44y26","c_street_2":"gLy6P00 yyyRL","c_city":"L2wP2kPPR 2w6N B","c_state":"m","c_zip":"613111111","c_phone":"555-982-5116","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.198,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"y 2k6kBky0RL0666RgRNN04BkgB0wNi4wR 46kk0ymyk2mm6BmykBB2i wBB4mN4yPykBiikNP kgBPiNLPw24B0NLB46iggwiLg244ikBNRLmigw4LRN gNykPyyPBiwLByg46N4yP mP2RmNBR4B6yNywk0R By0PBPRy0B0P kgmB62 40ymyPB 6L6RNkPBwP64k g0N0Bmm60gmyRRB yNimLPky6g RyN4NwB0yBkNg240mLgw2B","c_data2":"mLgRmR2R2Lw2RmRP2k0yLgNP2LyB4 i260g2wgmmwmNk4BLPBNR60wmNN0mgmyNPy2P2kkw4g4yBiRN yRmNg2m Pg0L6kwkgm PLgiLkB464kRBy k2iRL6L2Rm2mkLBPPwP w6L6ygP 4BikRkyBNBNg6 4Pkw0mwBPm LmL4gPP2Ry2L02R2Pw026m4iw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739156,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":6,"c_w_id":1,"c_first":"wRNNig 4L","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"06g PBmg4kyRLRg","c_street_2":"ikwR24m g yLP gw","c_city":"6B2NL4gik64LNBPBgkm","c_state":"L0","c_zip":"240511111","c_phone":"122-744-6923","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.05,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R 6N02wiy4RNwm24Lyw0ikiRk mRBmw2LmN LP0NmNm00P kyL0 2g4L0mmiwNRN4L2Bg24LR6k4PLgLBR266NB2Rm R wPiPRyi06B4k i0 0yP0B0Liim44yNNkwwiNmg2y4N62Pyw0k66RyByB6RRgLLRLNwPkkmNiBB06kPwN6w4mP4k24Rym62im ymRgLP6B0ywiyL0PNNBNPmPP46wi4 kkyNB4g0LB2LRkB2Lmyykk Nk NBm2","c_data2":"N24 mw y 2gim2BgBR0Bk2 0myPgNg wymyRwgm 0RR2442PRBmB6N26 k2 m2 6ywgmN2Nw0mBLgg0ywkiNk04i2i 6N2y6gmNBB4NPkyB22P6k4B2B0i 6wkmP0BikLLNBPPgk kBRRy62wi4N064R0BwyLgN42B4 NNP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739156,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":7,"c_w_id":1,"c_first":"yy0iyggkw0w","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"g 20 gyBi00gR2kP","c_street_2":"4RmRgkBgwy NLRR","c_city":"iL2Pi 44giLiyP2","c_state":"mL","c_zip":"618111111","c_phone":"225-701-8557","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.097,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" imL6P624iPyNBRRwRiPkP40i 4g B4mwL Bg0y2gmNkwwmBLLkigk6yy20NR0B6kkiB4N60m4BmLLgB iyB664N6w4m0mi0w2Pkkw6PmPLNygPwg NgyB22ykww6 6L6kLP2N2Nk miB00wiB2w4 PNymyL044gLmPPRR mwgNiy6R4wwwgyR6PLmNgi2 miRk2BB06wN2BiiyL44 Lmkwiy k402gwL6gN2 0RP0k46i0P6242kR2m","c_data2":"04PggN2Py2kgm44myL RwL2N0PPyyyw kBwyNRBBPwkRB6P6 60g 4P42P0mmgy6iNP2iw666kL6Nwggg 4g66m6Bg N02Ni0PL iyy4y4Ryig6gwB60wy2yR264RRk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739156,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":8,"c_w_id":1,"c_first":"NRPRNgNRRmRmRk2","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"RNL4y0NwwP","c_street_2":"Ni 262i6m 0","c_city":"y402N0LgB6","c_state":"24","c_zip":"883511111","c_phone":"214-229-6547","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4959,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NgR44Py0g2immPyPk0kNBN2NPBBiimNmiywwmgB42B6N4 N6BBi6m4LP2B6 4mR Bw22wPR4Pm 6Nwmk604Ngw2Lmg Bg2 Pymiw0L0L0iR0gBNwkLkNm0BmPBRLm04kmy0Pyk k222NPL0R6myiR kimL PPkN66LiiBwB6iPPRwRRRwgR0iNP2 P0R4iP2BgBiLm6 w4gRkwg2mmLRN26BRi0B2 LmNyL2mByN0g4L0PPw0 26BR B k","c_data2":"L6m6gNRm0P42ikL064gPgL N2mgwPy 2m20kL62PN0 LPyN0LLR0RRiPNigNyLigN wyiyR2i2NymwP2B2LNkyR4NkP0y 4B66m6 m6B40kR2gPRgmg0myL 6ki RRw6mwiPgkBkyLy64 gy0Lmyi02k4mBi002g2PwBgmykkP4wPww 4 mwm0m40mgL R6LgNywP0P0L2w2RBw2B0Bg 64y RPL0Nmy42m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739156,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":9,"c_w_id":1,"c_first":"gBm4k0B2Rg","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"i2mLg6i024N Rg 2iy","c_street_2":"6PyN44BmPi4g","c_city":"6yi6kLR06kmPL","c_state":"wN","c_zip":"820911111","c_phone":"977-138-8347","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.3773,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R44mky 64i6N g i2i064mNBmB0w0mmwy2wiLR0RPNPNgLg4BR66iwRB R4 y6mRBmk wkLLg 6PNk062L LmNk4w 0Bwy 0PiP0kL2 wR0N6kPiRmywR04B44 2NiN60iyygPgBmgym yk4igN4PNgkiBmL6RL mi6Piw6iP2 Li6 ywL0PP26BR0RNP6BNBR6N 2B0gg 4iN2y4RkR BkNi40PPL2N m6mP0iNyk4w4yL2y0k w0L","c_data2":"PNwgw iLP6gRPkR6mNPyiP4gL6 PwRgykgRLRgPB6k0NRwLRNNRk2LR4g40 P602yBLBw6RNiN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739156,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":2,"c_d_id":10,"c_w_id":1,"c_first":"PR LR 6gLkkk","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"g6LwPR m2yyymw0gP6N","c_street_2":"wBBiRmkki6mLw2P0","c_city":"iimyP6gLBR0N2kR","c_state":"ig","c_zip":"373011111","c_phone":"725-826-8430","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1812,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LN2606PmL0LkBm4mRB62P60mk0LPgRmBg4wNg2iiPmmgNy42BB0 24mk04Py0R 6Pw m2 gmLNm0N i4g4yw kRgy0PykmR4yPPymww 0kRPwyNL44R g4mBmykL4mwm0 iPP6LRP0i gBBLg0g L06wNPNwPN yygg2m64kLw2PLRB4Pi666m6yigmN6giR6yyLLPimRiN6wimgwww0mLgkkBg i4kmPw00kk4RRw6B BRmimLN2","c_data2":"gkBPiP0mg2gmB2Lm4gkRy BBNNw20mmg0P2R4wkgm0iy0ymwwyy2k 4yi4k yg0y yBy24ggPNBmR4PR26PmLPgy20i w00wBgRw60BkgNy2 2g4Lmm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739156,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":1,"c_w_id":1,"c_first":"giywRLm6BN","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"w6PRgmgi yL 6igN","c_street_2":"P2wymymL i","c_city":"BLywm gyNwi y","c_state":"6k","c_zip":"427611111","c_phone":"141-748-3048","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0743,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"Pw2gR2y4iB0R2w0NB0w0iLBykmimBkm6yB04wR6L2RLiRgyLBy PkRN44PkgR6N2ky2 wigR60y6PByBR242PgPy 6y2L L0 R6ByRyRRgmygw yRBLB46Ly02RBLwm4mR66w26NwkNg6LRN2R 2PLmwkwyP2LwLy0mwkRPN y64k2iwL0mBRBLi0N 2NNNmN Nk6ggRyNL6mmwLNPw w6R2RBB0w404P4B Pg m2N0L 0gkLL2w24Pm","c_data2":"LLRmRgPiw0m0ik kwiyRPR60B2 y0iB02wRmw0m0B PwBNwiPwgRL2 mgNL2 ymNP0i0mkkLL44ykk0RiLmg 200RkRiNN46iiBPgy66Bky0m0R6 20wgBkwwBB iBP2P60gyi40 P2N gkB NRyNkNmP064 4yyLyRigg4gyywwP 6ymN62iy00kLBLN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739156,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":2,"c_w_id":1,"c_first":"BiLLNwRygy6 6L","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"6 0gRR4 6mwmLyB","c_street_2":"y4m24gBi4iwkLB 4k0Nk","c_city":"k0BwN 64w4y6B6yk2","c_state":"y6","c_zip":"330111111","c_phone":"708-262-3397","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4474,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"4m4Nwiiiikg kkiRLP4g40g0y0myymg B Pwi0NNPy0 iLy2m24 4L2N44LwRgkmB0g6k2kL6 64kN4NN4 k2BgNR6iBw4LRw0 wiL2k 0yPkPgyg2w0i6P i BkBN6 2y 0iRPNBkkiPwiBB4N4yy62NLwPBiLNwyi0ykRk4k6yiBm4BL wk0Rm2N0B2022Lk0giLgw6kNNyLNPBBgRmN64R2B2RPPRmB4mLw0NL4igB6 06BiB kk","c_data2":"wkg NRi6m mBP24yPNii04NN0R6LgRywi0y6yR2BkkiBPgN0mk0RP460wwN2mg2N4Ng0Bgmg0y6By2gRm4ggy02kRkggNmm26kNNBRLNmi4y2iLNy60mB6 N4NiPBk2B0kP2ygPkPBL6P kNiNmik6PRRBLNNR6im0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":4,"c_w_id":1,"c_first":"2BmiBwLk4mkLRw","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"gL6 NiP Li0 y64","c_street_2":"B 6NykP4gik","c_city":"R20PyPP6 R0mi","c_state":"6B","c_zip":"574111111","c_phone":"372-875-8911","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0718,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2Ry6 kPB2N6kBkiP2iR4PNiLyg4LNRLP20wyN44642ywRyRw2wR22w 24ikmw6N4yN2ywNw6kwRwmLR0m6 NmkmNNii y6giwwm240ByLwPgR4wmBgyN6yyBiNPkB4iyRmwNP w0imkRmN00BmmmByiRkNkym6m kBkgyim2N Pk42PNNB0RRii 6wP0PNyi44004NR4R6NBggyR46626mwgBwm4NBNy 2imywg2mLgL46P2BkmkimyggR","c_data2":"2Rgy6NP kyii k2yBkw6NB2gkPPwmi4 0igLPBk0ykPkyw mg46g6mNPmB BigN0iBLkg0y6B 4ygm2ik4wPy62gPRgm4R0P2P mRg iRwPgB4y066wNLNByw62PPmgmgBg2w2B24 B PkL2y k 2kNg4kikLLmgBBi46PwyNL6 w4gkmRi2042mLNiNiiLRgkB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":5,"c_w_id":1,"c_first":"RkgyL4B22g2m 0mR","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"0000wgmg00g","c_street_2":"ky g2k Pk kNP","c_city":"ygRBiN0iyy","c_state":"g6","c_zip":"438411111","c_phone":"459-899-3839","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4863,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kPg0yBBy0R0kP0NgmB mii2L gwgN46PkRgNgwmB0LB4Byk6kky2BL R2gk0L2Lyg6 iiPiPiyBN iiRBRPBkygPmwB2ykymiiyRm m 2iP m00kLg0 g 46mBgymP4i6i N2B w6RBmw 22i2ig22wN4 RmgRwBNwPwP PygmkN20B2iikkLBi y0mNP 2y NLkNk RkLByNkgykmikPLmRymkBBgRgPNB BNL0yy0L iR 6kiNBmL0","c_data2":"miyBk2BL6yywPLB06wwy2kw mLwN4LBgL2 g02y2iBPyi PwNL PR0RyPBw6PgiNNmi6L042 2kgNw0ygRiig"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":6,"c_w_id":1,"c_first":"6mi440Riym2giB0N","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"m6NN6wmLB22w","c_street_2":"wg6gi0Ry Ry6gN","c_city":"kLm6Lgw40wgP","c_state":"RB","c_zip":"582411111","c_phone":"819-570-4009","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0432,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"0mmkNNB04iw m46w0Nkymk 2LyPy4Pk L0m6kNw6LR2400BiPRBB RNw66i LwyLwi k2mi0i0gB iNg4R6Ri0NRNiBgNyB04Rgk4gLL060B 6gg kBP0wL2gyPBiB iB6kRwmiBkN0Bm mwiwyw0wBBBimk46k6 mL Lk0mykwwgw2LyN4BBLmPPPNikL4m60R2Pm002LmwL2LRRm6 Rg6L 644k2Rw2Rii6L NR4yBR4 6w2kN4","c_data2":"wk LLy gkmB42ii44NRPw626iNgiNNyyRgN4 022B6LNRk6Pk4Bg2wyR4ggiywR060RN244wP62kL2 0wii mgLiR6iN4NBNgygRwi kwyN6wL0mLwyyP22i2 B2NwyNk RLBwPk62wmwk0P20mgw6gmkB 2NyP4By6ki Pw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":7,"c_w_id":1,"c_first":"iPm424 Lmy0k","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"2i4mL k6gNmi","c_street_2":"4iwR0622L kBL","c_city":"kgP4L gymww2 Rmi20R","c_state":"4m","c_zip":"703711111","c_phone":"658-548-9159","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1597,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" 4R20RBBwkg2L Py w26i02PP0 PgPgyNw422222mkwig64gyyB0 2g 22y6PB2yBi2gy04B2wR2RLgyRkPR2wNk266N6 LBRmN0PLi4LB40PR6PmRiwN4k y0 0mNwkikm4yw46RmiNwLNg ByLkiwwPPBm 24k6yyNR 42y kLgwNk62Pw6ii kNgR2iR02N0kL66 R4i0PBwyRiPRiRyPy44wwyg 2RkNLBkL22P 6NiBBBkymmm0m","c_data2":"6NygyyykmBRRNBmiwLP6y066BBRg4Ri2LkiyP2 mw2i0B4Lg0gy2i26BPkNB0Rm 2k y0wNBNggm2Lkyg0kRL2R4k R24 4N6066wBRiwNiRwm66 m442i6NN4g wii0g PNw0BN iB2yyNNNmLgwB 42P6g miLLPyg6ywP446mikPkki64k46PRyBm y i0LNLR00Pk4 PggwNyR6wkkB4kL g0mw mwB66yByN 46BkPNkBm44k2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739157,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":8,"c_w_id":1,"c_first":"2NiBmkk0gmP","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"2P y0kPNLBN6P mgw2","c_street_2":"L4NyPiLmB2gRw0B0ym6R","c_city":"Ri m6mk kyymR00R","c_state":"wy","c_zip":"693411111","c_phone":"161-513-3639","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1185,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PR B0R 0imkN06Pk4m Rk4y200RwBwNmkPi0Lm40gLNNPRg2B2N0LwiBi g k0PyymyNg6kiyN2g0R4Lg6iimRL2y0B044L0myPP6kyPyBmyy0wm6wPmg4NN Pm4 4iiww2iLyB2kLPgmkyN6m 2wiwy6RB 4ygB20gywRR0k0mi 4244BggRk4PN4P 24mkwNLg R4mBR0Lw6ykg iLBwiwwi kk4kgwyP 4B6PB BiiBR2N N4m4 4R","c_data2":"2600RNBwkigyPN64 26mP NkR6P6ykw g4i6B2kkmkwyk2LNkL0NyBymPky 2Rw402i6kPRBi4gR kgw66B2mBR0Rk4L6 Bi2i 6gkk20NiLg6B4NLRRR ywN2g02mgw ym0w mNPmiyN6i2iPwNkgNyBiik0206k40PPgPkRykN 4wi6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":9,"c_w_id":1,"c_first":" Bw6P2igNNm0","c_middle":"OE","c_last":"BARBARABLE","c_street_1":" 4gy2g20 0w0","c_street_2":"6wgLkN6mk 0PRLiR6LL","c_city":"kymkyPmmkgB0R","c_state":"mw","c_zip":"738111111","c_phone":"369-429-1671","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3581,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"04N2mR0LRRyRyNN62wPNmNyyPgRNPRByg6kPy R2NBLLLNiP0P4ii00 m4B046B2g4RPwgPP PgNwwyB22i0k L6P4 4 m6LiyygyLg6mywByy ii4 L24Pk6ggBL02gPgNg0mNPPRm4 B6RN24LB yByP0B6Nmwyk LyR 4yyL62RLN46k42kNLNiLkB64m6iPk2mPgL2wiR2gBNRiPmRN42Rg2k2gm06k 6migR0iBwiwkyN464k4k","c_data2":"m22PLB4BRR6PwB4y BmwP4yg4i6RkRPm22k62gykBRwBk6Bi2 PBN606L40Ng6kRiBkg44 By4mm4wR6kkRmLLyR 4LByiwBiiNR4RLk6y6 62gwRP4Lg6wNkwyRy kwmRPi yPRm0PPyRkyyPw6ggmBB0kPg mgiLw00 66LNRyRw6mm20mkPNg g4 2NwNBwg NN6i 2RNP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":3,"c_d_id":10,"c_w_id":1,"c_first":"NLBBRy04wmRBiP4g","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"wwRP2iR6yw2R","c_street_2":"LkL2mLNyi6kPLBgP4wy","c_city":"BLyiR2kgwmR6","c_state":"PB","c_zip":"173011111","c_phone":"922-300-3532","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0791,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"66400wNN4ki6mNmkRgPNwkkB Ni 22ygw4R24Lkyk PLP4 2PiN6wiRmkPiRkRRw6y40mRPNBRN4PBgwwNy460NPP6B6BymB2y4R4wk6P0yggNg2ig LPRBiR NmRN06imLm0m66gLmRLmBRgRmk2BRRiRPP 4P2N6gwiiLy4BBNBm4LmBLN RPkgw6Bi0w2NN6026m6mNPyB2PBkNP60R042NPiw6RNPPkym 060PPNkkiLg mPLPkB2g","c_data2":"Rgi2wNRyy44Nyi024NgPP4Rm0Ly04Bg60mmL P4wkPNBwik0 40y4LwNPik RgmBmykw0RB2mw i yPk6RggwN6Nkmw6w w0mBwki 2mmNk6myi6mwy6m66iLBRLwNBygBwNLgRy6B6N0Byy4 LNm6 2NNk4Li6BRyN6PPg2kNL2mi0wNNgN Rkw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":1,"c_w_id":1,"c_first":"PR262iBBy4R6","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"Ry2iLR0w 64NNy0P N","c_street_2":"Ni 6kgRR02y","c_city":"BNmRRP2066m","c_state":"6P","c_zip":"749311111","c_phone":"543-231-3696","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" N464R6P6gNLii4iw0BkN4R0ymB0imy6Lw2LiPR460L022NLyPi02k0B2i6ikiwRBB0yBRyBwN2BP0yk g6 0BmR B6Nyw2iN62gLimBLB6i6L4Rig4NN2 mkgkkm 64i2Lwkikkw0 g0mmgNwPgNNiwii04Lyyw0ygii6 L4gRNR4P046PwmR0LmkRR62 mggi imNiiByy606 0kmR02PLyiLw2BPRw0R 6 ym00 BikPg4w0y4PPmy4","c_data2":"PmN4N0kwR62g 44kwwy6LRL2LwmLy 0R6yyRNykyLPB 00m yR62N04RBB6igi2yi4gw 20Nm myw B6LP26 RygLBB2 2Nm0k2RkmLiN4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":2,"c_w_id":1,"c_first":"miNi0BPPNkR","c_middle":"OE","c_last":"BARBARPRI","c_street_1":" 4yw6BBi0RwNNkR","c_street_2":"4wmwL6NyLRkwLw","c_city":"yP4gmiBNkmy0","c_state":"kk","c_zip":"440911111","c_phone":"304-594-6359","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4999,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wPwgR2igk2NPL26LmNy Rm6gm2kki4wLkk6N2y2B yPmB4BkPNiw2i64k6RLL4 Lk 6R4w6NNRLNg2LkgimwkR46kRNwNPR0LmBk2 kLkBR46PLwBNPN2RkkNPPN24Ni260iPNyi0LwB PPmN4Rgw64BRyiyPiNw N wiN Lk4 LN6iBP0wkRLRm i2Bw2 NRgm4mkBkikPkB4gBywL PBgN0RwRRi60N4 2LiLyyLN0y 24ky0By0y6Lw","c_data2":"BgP4P66kwkmmLykkPkig62P2yyi PPyikwP22mi6imN46yk2Lk2RwPPi6RB62 im04LPNRByPBBkm BB6B0gN2Pg B0 6Rm2m0Bk446g4w6 w mm6B2ByP mR Bg42RNBi4y4ig2ikNi0Rk0BgPLwPgk 6ByB k iLi4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":4,"c_w_id":1,"c_first":"24RRBRL6y4m","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"gwNLkNk60gPw","c_street_2":"wNk0 6 mL P","c_city":"yR46gikR4yP2wk2k0","c_state":"kg","c_zip":"614311111","c_phone":"868-789-7458","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0553,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iPiNRP40 gR4g0N2L4kg6LygBLyPkBk6B22w6gP44kk4PwNym2N0ygg4wgNgL 42mBgBRL60gP BmRm 202ig6mymNk0mkkPLN4k0 gyywPi 6y2R2k0N i2B44ik0R04N0kg6P4ggRmPy2RkBiPgm06N4RP44R02NwPRP2y6gg0PP4kgNBRNLNiR0PiNmm4L42gBLB60k 4i4gy6N PiNkgky gLRNw206Py6mii44N24Rwgw6NykR2RR","c_data2":"L4mLBgg00 6m6NgN wi Rm2kPBiPNiimLwiRR04i4yywRPRP0PwPLB6N4B gwB4iB2iiBPBwRy64gNg622 kR0RNyL206iw0wi wgkwyNkBwBii26kRBLR0N6wyRwkg444RPNLPLNw6gwmw4mLL 2i yyLRm6Pim4yyg6L4LBkB662NwBigw0gLwPgP2R4yi40RRiL2ywP0k4yLRy2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739158,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":5,"c_w_id":1,"c_first":"0Rk4k64L0yiLg22","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"PkmL6yBLkRkmNP0k6P","c_street_2":"m0km4ym66Ri600R0Ri","c_city":"Ly4wPL22Rk2miik 2m0","c_state":"6N","c_zip":"504811111","c_phone":"625-239-6680","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.3864,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"ywimBkLgN60y0wgL 0R k LPmky2iN4Pyyyi0ww260kkkBRyR Nww2kBNBB2ikykmBkw2 y2gyBy6 R0y4L0PkwNyL6L2kL6mw R4wiky2Bki y04LwL 2 i6ymyiPBPkR246B0mB6yRm20NkR0wyy wmwL6N6 wy4 g6ikR4wR60k0P0wywPg44yiP6PBBm 2imR LLgBgkg44ym2B2N22mw0RP gmLkL4B0LBg2BNPL kRm6k00RgL06","c_data2":" BmLNNk6Nk42kwwLikg4gPPg6 Bi0N B4kwN0ByNgLP42Pwgy0iwNwRggiygRmmPLPg4N0B6ywL42gwig B4L NBB4Pw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":6,"c_w_id":1,"c_first":"2ww64mgRP","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"g4y0RRiLgBig0BRRg426","c_street_2":"44PyPw60PP2m26","c_city":"6yBgi64mgmmiiL00","c_state":"42","c_zip":"052211111","c_phone":"164-678-6958","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3827,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"N4 Ni2w2kg wyPRNR440PNPi406k42NNkLB4wy62mRR iwNPR gPgkigg4 im R2 y62L B60Pw00imiP04LLLLmL0wBLiLBkmgwm26m ggL206NP6PLw6RLLNm2NP4NPPyB g0 NwkkPBwkyN LmPgBk06B 2 m6R4iyRR6yB Bkk y yLkN0R0yiPLkiiy6PNNR6ymg2wPRm2kwy 4mggk6BLwg40g26NwwymN4 w iPLy 2i0Rig2N","c_data2":"RP442PgiB2w Bw60w LR2P4N Bim0iL0Liw4BLmBPgPgi Pg2mL2i6w4mPg0yBR4B y644wkkwkgiBN64 02kP4kPNR60i40NBgmB6 LP0kk RP 4gNgLkLk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":7,"c_w_id":1,"c_first":"0kyy2PgNkPBB","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"gRRmRgLPP04m2gk 2N02","c_street_2":"kkyiNiy24w4ki0","c_city":"2wRyR4y6mkP4BB0yL","c_state":"42","c_zip":"316611111","c_phone":"535-184-7311","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0851,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LP P wLky6L LRgyL2wm ik0m04 igiBPiRm4iP0NR6NgywiRgmikywm0iik4 60Ly4 yw02N4k0BNPmyBiw4km202Nk 64wLy w2RL6m44yLg6Bg PywLkgi4wm606yRyPik ig6PPyNmNymwNRPiP2gPRwN0Ni6B w2y0gy26kPR6R4 yP m 0wyB4Pi4Li4 kB6Lwi6wmgkBm4 NRmyRLkmRRiw44k4B6g026g6RgwgwymmkggN4 4k","c_data2":"gk4kikm2L 4 BkgRw6mLBBkyN6iLgi2P mgm2LkPwBgiwkii4NP2y2ym0k4LR L2iP RN4k62Rm02i LkyR44LN6PkBgi6yk0P4 iimgNwkgNwRgPNNB 0B4w4y2NNwy0RwmgwmmNw62i66mi2giNR6BkRPLNw4 26PB0g2mi6PN4LNw6gPPiR B2 gLw42LgPRNRPRB206kmP464 6Bi2g BNNLyPk 4 LL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":8,"c_w_id":1,"c_first":"yPgPkNwy64044Nk","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"wy24Ni0B2LNPLy","c_street_2":"4BB6NN4BRyyiR w4i","c_city":"k26mB2ywRP66igLggy","c_state":"gw","c_zip":"168111111","c_phone":"605-417-4479","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.103,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"R4L46RBLw mR62RRmP6BRwm24yg004iNmyBk62ykki0 0i0L B00wwR0 kiwkN6iN4RNNRw24Ngwk wRyk4464BNLwNm6mB06B4Rg2PNLiPRmm22gBw2P4w6R6gR46g2P0gk6200L4 4 4w4wB iim RBgmyLkgywwN0 ywNRwNkmBgm4gR 46ygRRBPNiN0L0 2iPy L6LPkBBk624igg4Biw4wi N24iggiP4ywL4wLm0m 4 2m6y","c_data2":"P0NgNBNikRwPyLLRkmkkk4L4w2kN2BN yy0kg4miPi kPLkiiLRP2g iw P2i2k2kiwRmi my064wgPPwLBg06mBkNLRi606iB 22m66LP Lii6R4y06NL4yNik4iwB62wBBgk62mkRR6 LwRik2PmLBkwwN mg0g6 gy4k0ikByR 44L BPgwNyi4iB24P6BR2NBg6w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":9,"c_w_id":1,"c_first":"0P 6kgkLyy22","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"iiik BL0kRL6ii","c_street_2":"g6R0LRwPiB4NR0L 20","c_city":"LkwNi NwB i","c_state":"Al","c_zip":"392611111","c_phone":"545-767-9187","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.246,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i6BkkB4wRP2PkkLP2Pw06gmgBmPN4RBgRwg Nk0mLmkkRg4LyyBPLPLLPP2wykNwymR 4BiiL26yLP2iiNL4RPNiByLiN2NNy y402wB2gLLw0iNyRykyN wLk NRRk2wiy6g6Riiwki6BLy0yyBmLB6iwy4B kw0N4NR2 Ngm2im2gwgm0y mkN0N i2mm4kB062N4LP4g0P66BkBkLg2PwwiNL0wy4P RkigP RNB20 0wwi2Bwy46m","c_data2":"2mPBkP4my02PyB0R 0 0y4 PL4Lwiywkwmw 00y 46ggL4gRwy2mN64iPy6wBPN42k4N26mk2BywN 4PR6wR 26RRykNy2ykLBm2B2NPy2L Bm2 LLNL440L0 B24i2 2R64mgmgPgNPPkR BLRNR m0P 2Bm kwmgwm 2640gyP6Ny2RiyyP w202N4Nkm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":4,"c_d_id":10,"c_w_id":1,"c_first":" P 0k46RwwmPm4k","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"6B2NP4RPg6N6 L2Ny0","c_street_2":"4yRBg 0B662RmmygRm4R","c_city":"NNNB2 w4y0BB i0","c_state":"Al","c_zip":"777011111","c_phone":"872-877-9126","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4281,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"w0im2giL6wmiP22 PmL4Pg4LB6 N2iB 4gw2Pi4gwgi0i y Rk0P Ly6B6N0RLL40BBNwBm2NRR 2m2P2gP0NBk4LNR0ky4Lm0g6P2NgPmwL62LymmwR4yiPLmg22g4k6iPgyR0gm62PkmBy ykyP6wgmww4PN4yRNiPkR wmkmNBPN0N2NB0k22kPwy0 0N0BgBw4B2gwkgiyRw Bik2gBLNiPPPP2im46kyBPRm6gB6RR4LLwNPBBwmg","c_data2":"2i6NNBgiiBimP0Lyiy 6gy0mwmNyBRB4 g0i64LmN g44mg6kgN2RB02mikgkk6 Rm42i i6Bgm2w0g6Rwgi0BPByRNkkkg6yw0ygRiPwwiP4R0g44yyyygmPLmR2gR R0imi264gLRywNPygBgikwBmN22NL064kB4mk4N0Ly0NyiP gmmyi mRiP22y2i4iyg4LB4g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":1,"c_w_id":1,"c_first":"LR26Ly4gmyk gNNN","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"i40Rgwmw2NL64Lg6","c_street_2":"NRB6im mw446gg","c_city":"BNy4kk 4myw","c_state":" k","c_zip":"417911111","c_phone":"626-159-6908","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1136,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"4myRRLB02 gBwm0iiPB4kNPiLg0iw460 mPgkP6L4NRkiLg40m2 B 26P2PkmPiy26k66BLyRPg24kBgRiBRRLik2NP262m L 0imigPP2g4 22NN6mNk 0LywyLwiwNwm4PLR26ykNyNgBB42 44 0B42LkwBL kB NNPRRRmBR6m0RgBL0y2RiLNP22Lwgw0yPBRy46kNyLLkRRNmymP6024yN0 mgB PBPmw NwmkLLP02yNw064g0L","c_data2":"LmRi206k0wNmwBBwkR604yk2yw0LNw0kN4iBN4L4kP64kyR4w4i6miRy6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":2,"c_w_id":1,"c_first":"ikyg4k6kRN","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"444gwPiPi2L2BmPB","c_street_2":"k2yN km2ykB2R22Pk","c_city":"kgLgkR6Nw 0wiyy","c_state":"62","c_zip":"423511111","c_phone":"874-658-7159","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2301,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gP0kNLLR40R2wBNmkkkikLLBLLN04 wmy0wRmmkRyPPRwmNRiwNyi624w0kNPkyB2464yL2k6ywB6PB4w40kBPPwiBPy6RigR2wgPByPP0PkPRgg2L26gPRNwNiNNwB4 i0NmLimPL2R0 iLk6gN6L 02R kkLNNkiPgkLgN6w6y6yyPmgBB20RR6yP2mL0NiN0 wB4yk22wyPLNL226yNRPwNygRRkw6yiPBimBBm Pm2 wkPw4 R6L","c_data2":"iBmiwgmPLBkRkPkwNmyNNLP0Bwg y4R0gywPkBN66kiggL0mg4w02 2Lgg240LP2 P20 Ni6NP y04wNy40gPRyN2Py Bmi4NRBwP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739159,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739160,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739160,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":4,"c_w_id":1,"c_first":"gg gRRy","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"2km6gRkm6R0iwg i","c_street_2":"0 RmiRBB N","c_city":"RNyg66Lk44L","c_state":"gg","c_zip":"944811111","c_phone":"437-940-9933","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.381,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"0RL 00L6yggy2NBPg06k2kwiL0m 0wm4LiLiRiykkNNm44 NN 4B mRLw44By6i0R 46m06igP60i2NBkg 2w0mP2LPy4PwR22gNN224wwNy4kBLP6gmB0gwLyR442yyPk4ww6ywN606gB64kg 2B4B40mwLiiyL0k0Rimy6gkPgNB4BP4PgPyyy6R2BNgw0B R4BNy6im06w6ggyB2ykwL4im4042miw my Ny L N0y2B40Bg gwiNy0","c_data2":"mPyL206m6L6kw62N4Pmwi0mL4LB46m4BPPLLBRiP60N0 LmLi2g gk0g R4m0B4wRNBk2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739160,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":5,"c_w_id":1,"c_first":"44Nm6gR2","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"0Rwm 40B PB k60iL2 y","c_street_2":"Lk4N w0N2k","c_city":"L yLg4miPg0BkmLkBN","c_state":"RN","c_zip":"101111111","c_phone":"607-344-1831","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.2285,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"mRL6RgNwmmgiyPP26kLR4iP02mw w2yP6NyL4gw40yg2PkB02mR2 44BwRk2N0ym64y4 LBiiw0 46y4i0L6gy24 BLBRg0P y46w2iN Pmkm0wR2iPP6NRw0iiLBgB2Ng62yBBwNRBmP06RPi P06ym44wy0igy0wB0P mPkN6L6iL gmRRkmNiRNBBR2N0g06g6mB4gk4Lm2PBBN4RkiPmNLwgii4w iwg 0Bw46gwByLkLiBw0w2L R","c_data2":"NN26g2R RPPNyg4NkR4gB422B2B2yPRNyi02kP Ry0P0m6PmiBBw0P0w4yyNkywNwNmLgNg0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739160,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":6,"c_w_id":1,"c_first":" yimR0kiiwR6P","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"y2L642Rmm42","c_street_2":" 0gLw mRL244PLR","c_city":"mLy2wkNyLRgmB4w60k","c_state":"mm","c_zip":"394611111","c_phone":"411-284-8513","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4375,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kgLw6k6NP2ggPm6 i PgkR6mBP6NP00P N40kkm L464ym0i2wiRkNNiNkN4y2i4P6km NykNRgiPL2iRN iiLyg20LNN4wNwm42wL4NkRyP2wi66RygkN6Bg0w6mPwyRg 0i6iPNg6i mN0gy B4 ky0 gm2gLBwwR20mRN mPgyLyL2PPm0Lm6BLkRmBPNw4R0yy 4g2Rk 0Nyyyw LRkiRiwkP B0kPi 2P2 N gwNN0y 0BwymRiB","c_data2":"mg26606kk60 k0PPw6L 26iwmBgmiR6L4R6m4L0gk6w6P04NyikBN4w0P0kRLRi wkNkwL62iwy w420iikPmiRgNg 0k RyLgmPk4R660yP0w0LNmm6 wmRiRRg2kRkw PiwyPmPLiLLgRg6mw wPw 4NNg06N0ky 4ik LP0wPPgyyNwmLii6N44 Bm4NRRwNLgk6Lgm6B2PLm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739160,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":7,"c_w_id":1,"c_first":"0B00P0w4LNy","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"Nkim0iwy0PkB0m","c_street_2":"RNRw2LLLgyiLNw2N0kN","c_city":"g0wk6260RBLL","c_state":"Ng","c_zip":"752411111","c_phone":"551-383-7570","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4234,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"L2 4gPg2kRBN2Nk66PNPkgkkBL6602kBkBL60Ng606264 mLN026Piw6gkigB6mmgB6P00ykykwmB BkLPPPy42wLNR22wNBk6P40 4kigmi Nw 4ki6LPi 66Bgym2y4mkLgByByNi2 yRkgP20iBy 6R2w4R2PLNR Ryg g64yy6 6yy6N6BgB0BNm2gmBwLikLLB0w4w0w06RLi2NLBg46 gNgPggR0RPi2w km2kwwN2P RPi k m","c_data2":"ww4gwRi4gy4PNN0w6LPPy6g2giyPki2Pkm 6PP0LR0L0Bm24i60PNP40mgim4y4 00P yy4iBi4i4 w6LBm46yBiwmLw60NPBPiL iLky2Pig2wyBmBN2wyk4N gwg2NimyiggyBPPL LiBN yL4L2BBR46k2wi400ykR0gg2yiNymPiim4BPPigN LikkBwy4Lmiw R4yki m R4BP22BwPwLigNwkwm0i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739160,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":8,"c_w_id":1,"c_first":"iNiLNR P Py","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"4y6i0BNkgmP2gwgyL","c_street_2":"g2wgR iRiigRiRiL","c_city":"2y4Rg026gBimgw","c_state":"NP","c_zip":"769411111","c_phone":"456-688-8303","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0917,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"44LNLN4N0 BPwPN LNNB04RPg2 wiwmBikkRmNNi4mN0BB NPgNR6 iigBR2wRwR2Piw 4LwywgiPNgPNL4P RkLggB0LyR66Bg2wgmRi6PyyL2Pw6 P0NB RmBP0i2g L4g4Bm6kwLi w62LNBRNL2yyyNBgyN4Rg N6my2RBLNPm4PByR m2k4 ggmBk4 LRyikPLPRm6 wy4Pw2ky4Bk44BPgyw 2L 4m04im62Pgw4kRmB6immy02L","c_data2":" ymR02Bg yPmyi42PyRRiB640PiBL4RR0R06wRN224yNggg60 kky60w2ym64wRwgmN20B6yN0i0iPL0Bmm2BRkBk 4R22iy6R6RP P 0 ymLm0L642i4g6P P6wk6 gi24PywkN6Ryi40PP4iN0 wiRP2LB Ly PL4RBgk2PyL26gB2RkmyBymB0L2BmP BBygPP 4wR4026NPPw44 gR24BgNBP22RR4k6wRLiRkmg2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739160,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":9,"c_w_id":1,"c_first":"mBm00i6BiP6mw02m","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"wmPmiP BLiwi0BP0LgR","c_street_2":"LPLRiN22wPN22BPmL26","c_city":"gwgy6BBkLy","c_state":"mk","c_zip":"753611111","c_phone":"153-928-8177","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0315,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"ig40wyBP2gPR06gk24P0P4mmiLP4yiyPPwPkwP2 BNN0k4ig4kkPkN k0L4mNB6kg 46yiy00wk6Lkm6iB24R66i B0kk6Bkk46P0R2Py4y2Lg46Pw6iwwii6mkk2w mm 42g06RkNykg0gk6Lk4RimByiwLw0PL0PmmyNwRBBgPm 06N0624P4Ng00Lm LRm4B4R2RR BwBy2Lgi60wiy46Pyw46ii 06g40404gw BLBmPmiByBwiwm","c_data2":"RRP6gw 2k042ww22ww2gPwP02mwLw4NPNk0mPRNL4wLwR4wPBR2ki4mgNmNP4R6 i Nmw6ym2k i0LNgB2ikw yLPg4RmgB24RiR4mPN24BBRPgP4iRRRRBkgRkyiy Lggk g2 mN2kN ii6iB20PmBkBBLN24m2R40g4w4LiiNkLwiLi0g4wP 0BNyyRy26ig6giyw2m6Py"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739160,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":5,"c_d_id":10,"c_w_id":1,"c_first":"R4B2mk6R","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"2R0B0i2PyyN","c_street_2":"PR4k446kP P","c_city":"2PR6mNkL 464yi","c_state":"gi","c_zip":"772511111","c_phone":"918-906-3675","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.0038,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2mP02wwLP60BmLwN2w4LmwiiPy BL6ym0 wP2kyiBm4L0w0iL img62 k0gL BNwykm4igPmik6LLBk4B0 wi2B6wL4mwyR2B gRkgkBB BwLR 06244BBw4g6Rw44gmNgB64PL44y0gi mgNPykkkBmR0RPgP2wiy 2w6gB6y42yyBRBByii wiPwkByBwgkgNN0 PiLw4Nmg4kPBRkkRBN6yPwgiB y2PRiBm2kLm6 6R6gw 6LmkL64","c_data2":"y22iw0Bk6i24wPNy 2Bg6yiBL0LB0mNPgPRLgBgP20N6i0mmmg LwyLByg42R6mmmLig ymP264ikmi2PPgPwBL4BmNgmR 4B2Lg0PPm20gm6gggkNNyyy0wLyLP0ymL6yikL2k0wR4BRgNyBBk L4NBii6 0RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":2,"c_w_id":1,"c_first":"6w4iww 2kg20 R","c_middle":"OE","c_last":"BARBARESE","c_street_1":"yPy ky0B02yPNLmkygyP","c_street_2":"gB B04m6 y6BkLP20","c_city":"L2 ikPkkNP0LB2w4 06y","c_state":"iB","c_zip":"769911111","c_phone":"953-451-4977","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1013,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"Rygg2 2w0R4iNN0NiiPLyiLwPyPwiBi664yimiPiBN0kLi020RRkgiBLyN0PPRPgikNmwiiNky6R42Ng w0P2kkRiwR2 Liy4g2Bm4P0i 2y4RNLBBLLPmy20yPNm iyLw2mgRRR2g2iw2gw4PgPwNRPyw004RPB6PLB2Bkw2g0yki6LP26 NNw wi mw4kwNL0wLNB2kykkg0Bmg4BiL2LgPiPggNkPLgmL4BmLBg2NgkgR42Bg4N2mR4","c_data2":"mRBm62k Bi20BLNB LN NmRP4LkL6gBL42i22i NmB iww6wggBkwgwiRRg2BBP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":4,"c_w_id":1,"c_first":"mkiymmR4gyi PL","c_middle":"OE","c_last":"BARBARESE","c_street_1":"g20iRi mk2kPy62gi0N","c_street_2":"mRNkR y2 Ry0w kgN","c_city":"w06kwPywyLw44y","c_state":"Al","c_zip":"023511111","c_phone":"816-833-4268","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0106,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wRBwRLB 2P2yNN6k4LNmNR 0B2By0yLBBwP 00R6yyyNR64wRBy60mRkPy404w00L22kkP6y0LimBLByk6mk 0yB NN24yykkyi6yRLmL6042LgR426wBwN64BRw2kL4PLkPy mgBN606wy26ym6B2igBkNB64kwLLwwBii42P4gmyBw0yw6g6i62PPwR2y 2RRm PLRywk0yNBykgNBk6gRmL2B24gmPyN 4 NB2PkmRigPkiw64RL0","c_data2":"gi6Li BmNg62 g24RLPP0wRyg wiwNNm0B Rki2 6iNNByP260g 6iByNikBP y2Lm06w2BgPP04BmPLNB620LmNN2kyk PLyN 2wmwkNkmNi6Lm0BLLwwk 4wNii mNm0RP00BkNRLBw4myg4RmmBmBLBLNP02kPN2gP0PByiiL0B0iwyLPiwwPNN w26ByPgNRPg0gwi22"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":5,"c_w_id":1,"c_first":"yPgR gk6RLk","c_middle":"OE","c_last":"BARBARESE","c_street_1":" y 4BNyw 46Pg ki4N6L","c_street_2":"L2kLkNi 6BggLB2","c_city":" k4 g 6BLwP6B4","c_state":"i","c_zip":"252311111","c_phone":"472-120-1296","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1723,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"P24mwy6wgmkwPwL0 6kgmw6PykimP0k6kP0Lg2L4 L4mwkwRP04wg2gLR6ki4RgPy0w2w42mRR4y 2R6wwNP0NmPi2 4B46R4iL4 Ly4BBL66 P0BkBiPiiP6iLBPwg0RRw22myNPN2gP 2P42 N0ik2Pi2R2R LPPw0g4gPkkNiw4LRPmkLP6 RgPk2Ri6B6m4640 ywPg yL kBwmiw4mNkk4yw6mLR0k4m4y2B RkgkN6BiyL620w N","c_data2":"Ri P6gmmNL i4yNwkNN6k gkmmP0BwBRg62 gikyB26wPN24w4L k6mkgw6LwPg0Pwg0i22B46N P BkwyLm 460wB04P m0iBy66PL40i6yBRLkRi4L6kkmiiyNigk0yPwm B4B40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":6,"c_w_id":1,"c_first":"2iPP2iwyNPg","c_middle":"OE","c_last":"BARBARESE","c_street_1":"02RBm6B2k6RNRk","c_street_2":"PL6ykLkPg0","c_city":"k R6BiyRyP6w R6R","c_state":"mm","c_zip":"290311111","c_phone":"186-281-2915","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3701,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BwyPw6mkByw mNPPPiNki6BLgLk0LLRm44i0yLLg RRNB mR4kN06Bi4mgPgiN6kNymk0y40mkm0kBL2N2mNLLggikRPwmP40By06imLLR6L02g2mPRBk2ykiP02BLgi LPB L0B N0wkL2LykLiBBPgP2g6mRBwimyLLBRRwymPgLiw0NNm4m46w2gy26wywPmL026wykN0BR4RmBi6gLk20wNm4P4LgkNwmB2B 6NyN Li4NL0g 6B2","c_data2":" NwRB 6NgP LmgRyg0gky6LNiNyRRkRm4PkLR24i ygL0 0wB2 N4P420LPN6LB iPi4P6B04g0Rk BiB0kBikm0Rw0iBkRNRBBiik4BkwP6mkL2BPiNRN6y4ywN4RN0i wk2RgykPw0 gBPNmkmL2R2kN20kyBBNRyi0iPB66w ykikigPBB0wB6PP NBii22kgN4LP2w LLBkiPmki m6NkB4 mLyw NN6 PLk iyPN006BN0m44BBP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":7,"c_w_id":1,"c_first":"iyygBywiwBwy","c_middle":"OE","c_last":"BARBARESE","c_street_1":"P4Lkm6gywiyLyy","c_street_2":"kkLB 42N4BggRy4Pk0B","c_city":"k2yLPP R iwNBR2","c_state":"gm","c_zip":"722311111","c_phone":"602-453-6077","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2924,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"02RPkgN0P0R0NLR0gLPBkwky02 ByPB4wyyBRikRmykmm m y0m42PiBmNym mw6By06myRLLRiL6BmBmBwLRB6LL2kNB4L0 0myL640i0yg0kmi420L4NBNyww2y22NNk000RL0gwgm 0m4yww LwmLy iPwy2wmgi02PyN0 RB0ywg 226miBPwm44PgLwygPR4L4kk6 gmm6 4g6BiLmP4imR0BBwk0yBR ygB46 2LNimiimi 6R04","c_data2":"R0mwL4ig6Pmy0mi44w4PkBy6wP4N0m4 g4B B60Bg0BwNmB PikL20w44BLgRRBm wP620Lw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739161,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":8,"c_w_id":1,"c_first":"NyLBiyyw2y","c_middle":"OE","c_last":"BARBARESE","c_street_1":"gP4Rwk6w4g22k26","c_street_2":"2B2 L0wwNmBg PwRNBkP","c_city":"Big igy RyLR","c_state":"40","c_zip":"079311111","c_phone":"702-728-7110","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3836,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PLgmN RPyk4RwPwikR2 2B6BPBP4P0mLg06wkiyg6N0PiNBR4k42LNi0N6yL6ikBB2ym RBy2kPBmB0iB 6B4ky2wR0Rm4BPgy2BiwLw4BB6RPgw0PgwgB0kwy04R2i6iPgm m6R2yRk6yN P2y2kyRLi42Ri0 NPLkwwkk4gB622wRNN42kkk6PLB0L6BBPkg0kgwgm kLB i22m0L0L w4 0BiBP RRi0wyRm2wym2Lm6PgwN62mNim","c_data2":"R4k2 gLmRgLLPP R244 2Lyw2mkiP0k0RPym2g0Bg Pigky2BNNR kkw04yNNNmN22g0w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739161,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739162,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":9,"c_w_id":1,"c_first":" mmk044ikNPky0","c_middle":"OE","c_last":"BARBARESE","c_street_1":"Nmkmim4R0L kgkk 6","c_street_2":"y4g66iNgmwBkP","c_city":"R4BB0BPgPygkgmP0wk","c_state":"wL","c_zip":"554111111","c_phone":"939-368-9959","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4241,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" w6mLki0wkkmB2B kk6i6k N w0R 4gRi04Rw g64y 2wL6ByiLRymNiw6wNwk2gBBBwNkwB44PNN4gwgkNBkw62466N4B4NB2PyRLkRy0m460y2w2g0RPN26igNmR42gwPRL4NwwPyLR0wk2kigykwN0PRmN4NkP0g0R6ByBNwkmw6img0i2ii0Nm2R RR6 g4 0BL LNwNNyB6yPP0i0Lm6gNNRwBNmym6Lmik i204w6gPBPL0NLNmB","c_data2":"wL6i2LmP2NBPk NkmwmkyLRimPR06igmkPRB0mLNP2wBBLkgP4 yigRm 40iRPPgL6 PkNk02N46g0w2Lmw4P N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739162,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":6,"c_d_id":10,"c_w_id":1,"c_first":"wNP6R4ym 0","c_middle":"OE","c_last":"BARBARESE","c_street_1":"0PLB2g iLkRw4kg4i2L","c_street_2":"2PPkg0y4B g6i","c_city":"0LwNky2wkkyRRi","c_state":"L6","c_zip":"580511111","c_phone":"848-858-6621","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0086,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"P0wLN0k0gwwLg wkgggy4ygwLkN2P44BiLRPN02yBwL 06PR6046w40yBgi0BkN iBwgm6LgiB mmP02y2gRwy2w0iy2BNyk42LiPPPiy04ikyNwBg22ggP02 B LBwi60mmkw 0Lii2ggmLLiLwg R40gmwLPNL2BRPBk N0kymy4BiNkP mg2Nk LN0B6yRkNw0 iigLk6w N4Nk2NPB w64g2Py40i6Rg0PLyiNmkPiwLmB4kgm0wL","c_data2":"wg g NLw wii4mkyi2RBB4BLkL0Li62LNP2Ni4k246BNm6kw6kgRmimBkg2w0PPm imPwRywwL204wBL0L yRmm kBBiwgmRBgByLg6Rww"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739162,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739162,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":2,"c_w_id":1,"c_first":"4k 2my4k kgRwN","c_middle":"OE","c_last":"BARBARANTI","c_street_1":" 0w0i04NP y44LgN6","c_street_2":"4m0 Lk00i N2R m60","c_city":"i6By BL wmk R","c_state":"Al","c_zip":"185511111","c_phone":"228-534-4528","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4959,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"4g0gPy0R4yP0yy2ik0w iRRNmLP0N60iPgLwLBLm00wNkBk y2myymm mi60kPLN6iPRPi6kk2PB k Nm0R4Nig62BymkgPy6P4 6mkmimRN BN4k2kw0g4m0mg4g4B4kwm miiiP0RgwR2N6BmPRLkmN2LPPNk22L6NmLL4i6N4gBBgw0BBRim6BNL6yNLL6wm6kBN4wPN6wgPPym0g0N6wLgkigyBmwB0460 BmBmyPNyywB2i6 yN6y","c_data2":"Ni4yPR yym2gLww02y4ywBPL0g 2 im60LP P404kR2PBikPywRByg 0NL iBkLyg00262 R4Ngy2kR0RBwm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739162,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739162,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739162,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":4,"c_w_id":1,"c_first":"4i262w6g mgBi2","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"06yik2g4PkNiLig","c_street_2":" Lg4B40BL0440m","c_city":"PgN2y 422Lw gP","c_state":"6R","c_zip":"728711111","c_phone":"714-875-8566","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3706,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"mBgg6R0ymRwyNy02g wyP6BmPmByBwL0Bikiw2LR4ig6yB0m0NiP0k6LBw44P6yP6PRwgy46iR gBN0N kk6g22Pg464k 0Nyiwk0mii0ki6 kg0gkkkiNRgiR4k2iiimRw42Nk4g6462 62mm gwNygmmP2BB4 m wB y62i0 4 4 i2LR4wPL022 4RLNm2gikii0kygiNgN 6k0y2P4 imw2yLP0mkii2w660 2R0RykRRmLBmm44","c_data2":"Rm66LmkLk6wiNm 0Rk6ykwmyNy mBki0Bi6g2kk64Bmky BygL w0By iBRgPNP4y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":5,"c_w_id":1,"c_first":"RBL6Lk4imiRL40gi","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"i0k6wyi 6i4Ny24B","c_street_2":"y6kN22iik22BL","c_city":"46R4Rg PBBw","c_state":"44","c_zip":"446311111","c_phone":"207-246-2175","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.173,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" yik2kiP06g64Bk6w 24m6yk ywyyiN46kN22BiPP 204kgiwyi gkw2Pw BLkwRy420wR kkPw6 Piyk2yPwRiwRmy gP BL2Bww wyiLLN2wP66g0i4yN0g4NRLB640NNyBwywN44RNRmyk kL 2PgRBPLNg0g y2LkwmB20kwkPkim22gL4kwki6R4 N24kyBPNkR wBw B6mymwNN40mi igwPLyLB0gRRPiBR2yBNk4m6ik4kR4i","c_data2":"NRNPBRNBw0iiRRNwP0mB 6RRy42iwkwNLg26iRkiyi2Ng2wBLg2R0N6RBk4PmPkLmmB4yky0yRiRmL06BiRmPRkw6026PNL6m4PiByw6g6P 2mNL0w0RigRmL6LRmRgL2wBNN64gBi6mN2iRkNP0PRgmwLB6L4giP2mNL6gPg6k642B0wigNLgkP4NiLLw6N6 gw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":2,"c_w_id":1,"c_first":"NNNmRw Rg","c_middle":"OE","c_last":"BARBAREING","c_street_1":"iwkP0gym40L","c_street_2":"wi6mwmk062i2w2P","c_city":"mw0R L0y 04Rwykmw","c_state":"i2","c_zip":"451711111","c_phone":"555-390-7199","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1694,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iNiwg24BR44m2g6 N2 m6 gP44NP4L6Lw2ywL mmygPymRBBk4wmRmRB44kRP4yiB4wNyiwi6L40BgLB4yikPkywRL0m2RmgP60iBRN0N2LyPN6wLLy2NRyk0w6P N40NmmggLRgyg44R4mmw2wR0RNR6wkiNg6wm0kmgRg0NmgNgy2 L0gNLyBm0iyiiw4B Bik04RNy2ywi24yi00i Bwy0wPBwP6k 4 ykgkLykL6ky NkR6ggiNwR","c_data2":"2RwLkLk2N 40gLmNPwgwkg04BRiPyw06iPRikRygBBg24Nkw2 RBLkwRyBPyw6g0wg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":6,"c_w_id":1,"c_first":"4igkk44 w6yN","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"2N0wwwwkB64PRP","c_street_2":"iP2Nkkwg B046BRBRB","c_city":"NRPB2B P 0BBw20yRN","c_state":"Al","c_zip":"633411111","c_phone":"746-634-7967","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1962,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"20NmgBmmRB 62 BL2By kg2L6P00PRPgmBRRPPBigLmiBPR20kwyiw0RP4y2RPB R6gRmNkNBPkNk2kRP m6B2mgB6iw4ki02i20kg00wm0k yymiRPNRiyg02kwRy PRmgwR6y6mwk4Ny0m gNR6RByNPR0w 4L4i06wm20gRkN y6ymP6igLP0Nii2BNPNLB RiBLBL2 02Rwkgkg2mgNm kkLPPwk6N0g2LRyLmimi 6L6wkL022gg","c_data2":"NyN 4 kNiLiyw26ywyBgwBy4m220NN0PPkwy4gN0w0RkLNm6 ym0gw0026w2y0k0BRgR2Ly6gik Ngm0RRyyggyL6BwmBBLByR2NwyPBkyBLy 66k0 PP6w6 20BB64R4gyN2BwPNB gmPm002Pk4yB6BLN0Ng4i00yPN 0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":7,"c_w_id":1,"c_first":" g0Rk 40Rkkg4w","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"0NPkR4gB6LiN4ig0B2Bw","c_street_2":"B6mRg6PRR0Bm","c_city":"RB424kgBw66L6","c_state":"R6","c_zip":"126611111","c_phone":"133-198-3531","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1983,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"02iwPB 2i2BB4yBgi622PRR4PwByNPNy0 m66Lwi2g0gLk LLNg6PP 26Nw0BB4y02i6wiNLBL2NmiNmi2N24y6N6Bm0 myPgy mg P0m6mN 4gy2w Pg6m0kR06iy4kgkN0g2Bygi6kPkkBRRP46P0Lwi6m PN2i4Ngy0N6R 2iNywmByBBPgiiRRyN06kPygN0PLNk42gygLy0gN 4kN40igPmgg62w62k0yLPLgm wB0g0ggBLNRkPg","c_data2":"gPPBg wk4w w6L imgP0iB4ggkyki gmw 6wNPPkgkNL20RiyR4k 6wB gBL20kPNN44LB2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":8,"c_w_id":1,"c_first":"mPmRmNiR4i4ki","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"kP4iPki226 6","c_street_2":"6gP0iN0B mgm 4gk","c_city":"ii LwN0gR2 kii","c_state":"ym","c_zip":"265211111","c_phone":"697-448-1546","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4229,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" L6BRwg N04ig4iywk0iBN0gLNm R0wNgg6BBy44m0PkPiB6 mLwkNP04w06wLwBNyyBw6mw ByNwkwm6BRm iP PNLL2 4BB6g4k4iRwLiy24BkiBNL6Nyy4LRg mR06m2g4BRLmy yL2m40PPkimN 4R44Lwyy 0BN4m gPLB2m20R0R20kLgkwNNN2PkmNBy4NPiw24Nk N066LyyLkm N y4iymL42g0L2ikyNmRNRNwgwmR0kmk","c_data2":"g4yLN22m4yk4mgPB6ki26gBPk022 0wikLPP6yi6kRk Bk kPw6mPm0B0 yww 2y4 2Pk6 wy6m N2i2 iR0BN Pk0Bm6kRBRiNN P0kwymgL m0BLBPNm k RPBik24LmmBR24ymw2wRiBkwy2wLRLgimy kB gmBByii4mR Nw244RLgwwiBwiLwk2kRBLwPNBNmw226PgB 26RNmN6 R yg6Pg6i26mm2N662ik P2PB6myNi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":9,"c_w_id":1,"c_first":"6wkg BiB40","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"gLPkm6406 L4wR2i","c_street_2":"igPBimPBwRwgiL","c_city":"gBBL gwyBy","c_state":"kw","c_zip":"340711111","c_phone":"912-627-2447","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.414,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kgwmw0gL0g0 PmgRP2RyyL0Ng4B64wyk6L6wLPRiN gyNmP6P mPw4y2mLgRy66BBN Pim6g6B02wgNRPmwywgi2mmL6mB244gw2N0y0BR60y6wwBL0ky0P0 4gyBikN20kBik4R00w gLwm 64LN6g w40 B4k4y2w46N Rm0Bk4NBw2PBg6kNy0m B24N4 NBBiwLNRww04kL2NikLN4NR40Ly6N6yRygN0myi4im wiPP02mPyLR2mw","c_data2":"wLRRg4P4Bw2PPiBmiLiRyRR6mNy2604 BBwN6yygy2w2Pm L4y0LyL26440LNN2ww2RNmwm P2y44mNBkkyR64R0BP RwNL0P2mmgLwk2kR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":7,"c_d_id":10,"c_w_id":1,"c_first":"wmm6m iL k6i2 Rm","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"w 4ii4mw6k","c_street_2":"kk4m 2w4PRkyNkBm 04","c_city":"RLRPNP2i PiRmRyR","c_state":"yR","c_zip":"613311111","c_phone":"660-590-7617","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" 40PkBk mNB2gPmi0L2mkmgwLy0g2mPmRk0iPg2y4Lyy6gBR6Nwg0imPkRP k iy4BkNLkw R6RPL0L2Pw0g2gNg24k4w 6gmywiwkgyw2y402gLBkNmg P62L4024 wN0 BP 4 RRkgB646BBLBPR 6m2RBNmy2kNygLwRkkyLNB06 w40k4g6gR20BLk0yN2yBPgw y4PimwmkPk66wgm0LkPL0kgyN4gRiPPiLPgm04mmPPgwg4wP4","c_data2":"wNBNRLN ykm6 NNgkwyiwk44ky2 N42gm0wwN266y2miwN0gmB2LgB2240RPg0mNPm42L Ri4i g2iLyi yPk0N02gLLP yRLN6yk2NwyR0P4w2w2 4 yyL42yy w2w6NgNy0 6wPiwNBRmLRBB P 06gwmk0 4BmLk6gi2BwRm m0myLN24mi0m46yymNikByRiwBw4g02L0yLwPR4iwwLP yk6gk02y4R0kPR6 4Nm NwL6w26Nm4RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739163,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"Al","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739163,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":2,"c_w_id":1,"c_first":" Byw wRy202 L2L2","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"PLwNP2Nk4 NLk y","c_street_2":"mi0L46BBwLPPwm4m","c_city":"wPw2BP6RRkPk PBL42","c_state":"Al","c_zip":"018511111","c_phone":"517-371-7996","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1791,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"2gg kiNP4gB2LmyB w4N2P4gR0gN0k 460BB0 ig64wkm2w4R R 64gmwmRwkky6NywBRgRwBi k4NR4g Rikgi4R4 6 RiLmP22i2i6yiBNk2gRmPwLm4w40ikkwkPk64RBk mB 46iPwNN2R0 k0wRwPm20426k4m4iBmRNNggB6Lwym00w4 2Rw g6BRB22gkggB6y RNw k0g2m0 0Pw4NmP6BRiiRL6mP6g6 m4NR0LByRy6RyN0","c_data2":"P0PP6y6g6NNL6PP 6 LLiiNg iP6P m 4LB RLL26BRmPNmmmL44P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":4,"c_w_id":1,"c_first":"2gPyLNik6PRiy","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"k wNykw m6gBkww","c_street_2":"kBwN6 y NiNB4PR 2","c_city":"N6yNyL6RmBgLkwRRw4","c_state":"Al","c_zip":"590711111","c_phone":"218-218-7646","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1122,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"ii0LBNg 66RLg02 LLP2yNL Pygk4P2wLPmRg40w04w4LRkmwPN04imiyLLwLyNkBNNm LP2g4iwm2ggBwi m20km 04P0m00220 04ygikLRN0446Rkg02PiiLRByN660NB N0 gN2R4iNRLi N mPgPNgy4Lk BPNByyi6BwNwN6PR wBgLPmykkPw6mg y6Ngwyi2 Nky2iPkLN2RyR 64Nk2igNwyk0k2 N4w6Pi R00gy6LBiyN","c_data2":" N NRB4wiPgk02P4mgwNkLN6BwPLk00BP2yg6BwLw2wNy6B2BLRyBRN2Ry42L y0i4ki46m26LPNNL0yiL2ywgLm02ig0R4Ryg0Bi0PygiLgk2 BikPPgigm RkNNwgmRk2LwmwBBm0R4yi6w2kNN4NN00 PwL ywym g2BB0L4NLN62w2226w260g6mPyRiNLPyii00gmL46y6gBmm2Ng4Pm yPPmik600wwLBwm 0B mikB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":5,"c_w_id":1,"c_first":"wg40P6wPwwBN","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"g0gi2NL4424","c_street_2":"y60iRiggR4N","c_city":"4NL6gywgN20 w4g4666","c_state":"L4","c_zip":"842711111","c_phone":"808-621-7085","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4748,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"22mm2wwLBmmiBikm0kymyBP w imwBNmgBLP06wg0 6BwBBB4imiB 0m04BR60P 02yP00P2BPL LgPNmgNwkggmBP0wwk6PyPm0LNwB4RL 0PLi2wwRR2NyLRBm0BkgggymNywNmgPP2N4PBky0mLB42B6iwN4kkwk2422PPk0k0NmgyBi L0RN Lmm PRm 6kw yg0kikw220PP Rm Lm 6LwLk2Biy2P4RmP4iLmPRLL24im6B2 w","c_data2":" ky 4 6gyy6Bm4ymiR0gimBPwkRmB6PwNi6BBw60NwNByL2B0w2PmBB P2mi6B6 y4 R6LN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":6,"c_w_id":1,"c_first":"ykmwm4mi4","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"iB 62L6kkBi i","c_street_2":"66LN 4N2 66w2","c_city":"w0wwBw2wPPLL0gi2","c_state":"RP","c_zip":"641311111","c_phone":"356-874-2301","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4188,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PBiiiP62g4mwggigkL yLR2yyN6kymiNm6Bi6w2BkkNmN46Pim4 kgmm 4 PBLggR0RgL2BNL 6yR0NigyyLB LgLkLkk6mN N k2 ggii66L kiyPm22y2R640NkBii4Ny4NBPkP62yw0m4kNRNigwigyPPBB2w6Lk0LLNBRL2wBPg02y2yy6LP240 RiBy440RgiywNg4k44kg R gRggP4R0y0gNmR2PggwL444w0yy040gwywR6P","c_data2":"LgmP 40Bwy2i4RRgk 0my6mgLi6LNP6Rm6LPLwkL64Rk4 0ywkNgmmL k Ry NBLB6NwyL2RwPmwk 2L0ggyNLgy iiLPw0ikP0LL4m20PkPgk00w2N60L0N42ykwwkBPBw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":7,"c_w_id":1,"c_first":"0R6mywkiyi","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"BNgii2wLwR4i66yPyikk","c_street_2":"LByk 0g4kPwNm","c_city":"wwB4wBNwgPgNwNP2","c_state":" R","c_zip":"767011111","c_phone":"875-882-8213","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4076,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6wgwm ygPP 2w6iwLLP042PBwy2wRRw iiBLk LwwPNBi2m0miym6g6PiPR2mkk04006L4iyP42P Nk2g6y4gig4m2220 mmL2gm0N2gNwRLwRgN4kPR6wkB4RNgk 0PLmgN0226 Nm yNg40i6wg2RmN2gR66mRRPN0Byy2LP4w4gw6N4LN42gN2k04gPiB 0m60mk 42N02mmRk igy4R6 6mRN4PBm w0m6PPi0P 4y yg0PLg0g","c_data2":"22i0PimiymP6 0BPNy2RPgwmwN0P6kByi wkyLwPm4RNN4kykwP0BykLym0Ry20Bmw62kky 0B6w 2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":8,"c_w_id":1,"c_first":"mwL g iwi NN0w22","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" RPmByi4PN mR mgm","c_street_2":"PN 2NPyB6i","c_city":"Lw2kykmRN2kgiR2P6w0R","c_state":"Al","c_zip":"052511111","c_phone":"186-295-3252","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0209,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iRLR 2yLg2 k Pg666Bwg0 myg0L0yR4imiR0PR0LN4PLg6 iwgBRmPRRR4 4LB4B2Nkw4Ly0ggw2gLi4kii4mkR4NL4gR P LkPBwBgN0wR0wgiRm6i4iwNPBiPk64 g 0LRNRLPg P 6BPNy02RNBLy44RkimNB ygBk2NBwk4yL4yykyg4R6NPk0R4P4LP24RPL24mBN42R 2Bg0BkBg0602Rgy4N RLgB6wigmkLiL4NB6Lm26kiL","c_data2":"NiPNmRLBNBg4y4R6 iigm4Nwy2myP22Bi i0w gPP2RR22kwgR2P0R6w6wPNi i6PmPi6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":9,"c_w_id":1,"c_first":"4yBP2yLyP64Ly","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"i2BiPggNkPwR m2k6Ry","c_street_2":"Bim 0 Py4iN060y","c_city":"6mykmB4i6g6 Pm44m","c_state":"gP","c_zip":"488711111","c_phone":"959-374-5343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4765,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"yiRBgwLLRP4k6y44RLBLPiim4 wL2ymg0RLii20kLm6m46ygk2L6N4PLB6wL k4RLNky 6R2N26L 42446mgik2wwByLmm446 gyiPN0m02mP6Bg4NBm BL4ky6PNk0 g42kRPwi02Bg6migNBNi4BPy2k iww0iBBBmkLByyPmiw wL4 i2gkR00mk Li6NRLBR4iy Pi0BgkNiRRL6yNmyPNiBL4gy6 24k g6mg0B4R6mm20RLB2yw","c_data2":"0LPgL0mBB44k0RNgwiL 6 ByLwPLNmiP 4P00RmigmPikw64LRBByRi000i04m4BLi60y0kwL2yBki mg60 wiBNwL6g60LyN26B46"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":8,"c_d_id":10,"c_w_id":1,"c_first":"BkRg g2wwP4iRRi","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"wiRyii0gmy2P6","c_street_2":"BL444 wRk 0L0ig","c_city":"0LiiPPwggy","c_state":"2N","c_zip":"998411111","c_phone":"415-587-9162","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.349,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"P 0NwNy NkP wmRN 66Lw020w4kgB2kL RLN LLPRRRL0wiBRPNyw wNkimm6Rww6BPRLRRiy0wLi6kR m RRwBPRNNNwNP0Pw4gLwN4P 60 g6mPR26wkwwNL PBRgwP6kwB BLLmL0BNi04L2k2224mN0yL4 4w06m4 g2w2Ri2N6m4yR PLy602gPiyRggw mLRk6miRyRwyyNkkRB6P0kw6L P 6mwPwRmRwB2NNgkkkL6mL 4m g","c_data2":"0iwNyPB2gyigByLw0L0wLLg2 R2RPk0y2giwPy gPLR6w4N6N2L446 wgw0m4kR6NRBBw 6B2R BR0RNiLyPRgwkmN0kBk g60Rw4L L 6L4y0RNgN 02246miLgB6 Ni2yR22k4wPm4mNgyg4kwN6LL6g2RPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739164,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":2,"c_w_id":1,"c_first":"igykgiwRwm2 P0NR","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Ny2Bgk0L4w6kmi6k 2L","c_street_2":"BPBgLm4w0k6Pwm2N","c_city":"Bgyigg02R06By","c_state":"2R","c_zip":"183911111","c_phone":"766-299-8660","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2827,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"yBLy6kwk4BNwN2km20R0 00PNPwRggiRR0g Lw kL4RiBk0LiNgm4y 226NLN0ByNw40 wgPB2266wRggLgBN44yw0 iigykPNNmyiRNk2k6g4gk4646mkLk04R06iy0PPR2Bi46 w4RNmL420RRgg4gkBi6NymR0g4 6ywyLBRiyk 4B4Ri42wi0mLPPgB 0k2NBBw Lmw2k4P0i2mPBy2P6imww0P6kRi64L2w PLL2ykk6g2kPiNwPB","c_data2":"6kR44PB BgN 6m N4yR22B6RP R2m2N4m26y gBNN4i0mLiB2g46 iL0mkR6Nwwm4L kNgP6B24P6 gmyNgNyP ygPgLB42LLm24RP mwk0i04BP6wyLB6PRki44LP44yi42006wkB0Ly64yLB2i2 w0kiyk24wmmk Pig0 0P0RPR2m0w4 L2Rm204wyR2wRg20iRL BB02LiywLmN4kR6L2N iR2Pk Lkk0L kkgk2i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739164,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":4,"c_w_id":1,"c_first":"iLykym2PyPNR4wR","c_middle":"OE","c_last":"BARBARATION","c_street_1":"g60RB BB222ii","c_street_2":" PyRkwgRR6 RPNyNm","c_city":"2P6wNkN24NgP","c_state":"Al","c_zip":"718211111","c_phone":"912-655-1882","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2641,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"B4N2ig2BBywgBg ywiNLiwwLw66iw4NgPBkiRPB 6 wNiN yRBiRykB6BBN026NiwN igLNyRPRNyg20y4 PkkmP4wRyww0P0k2 B0RBgy gLg4R4iPkNy0mkiLwykRR6y 4R4g4ByNmw6iPimwBgmygLmgkymRk2kRkkkPL2mR4L0gLky2440LNR RPkPyBw w0kLLNL2yLNw2 y4yiP LLwN4Pg0L 6PL0Nwky2mw6g0RBgPR2yi2m","c_data2":"0yi 66PiNBP2LLmL04LB4ki0RLBy206kkyiwmgyPgywg6P20Bwy 0LNB0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":5,"c_w_id":1,"c_first":"iiwRgiiLRPg","c_middle":"OE","c_last":"BARBARATION","c_street_1":"k2B4g 40iyw22yi62P w","c_street_2":"LBNi0 N60y2 Lg","c_city":"L0B02yg L NByk0N400","c_state":"kB","c_zip":"315211111","c_phone":"736-825-9426","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3129,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PB6kRk2gNL0mwyk2gi0wyRwPPymkyyLRR NLmmwg6k BNP4PyNy0iL4wBNPmB6LkP iPywyy R LR 604RNgi mRR2mNym2 Riwgg4LB4NmyLkgmBk0y44wiky PwN46ii2ywiB2LwP4gwg0iP6BB0 y6P0ykRwg6wwN R2Ni 6Nyy2mkLyw LmgwN0gmPPBiy2y6Bgwy044gB0BmPkB4RRBLNk kwL0P0g6P26 RRk46R62B2yBiwBNN4","c_data2":"LPBLPB604Lyy yLyi2y6LBL R0yw NLwm BN4igRm 2R0P24kRiLm2yy60kg6ywNRgkmm224kmi 6kgg04B2 ky20gwPy2 yN4m Rgwk6P62m0iwL4m6yRmgiB602yk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":6,"c_w_id":1,"c_first":"Lm4Lky22","c_middle":"OE","c_last":"BARBARATION","c_street_1":"w2m2LiNN6miyg4","c_street_2":"26w40g wPRkg","c_city":"4my NmwPkR k4","c_state":"gk","c_zip":"051811111","c_phone":"666-926-6387","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1542,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"yy PRy0yNyNm0 RNL44k6Rm6w6m0 w RN mLgNikyk2PRm0B4Lkk0kNwwi2mLi2wNwL2iiB6LLNN06L6k PNR40L4PgPy6w 4iPL0BiNgNNiB60kkkNii4ykRy00w4kmmwm2PBRiPL2m Rg4kk2PwN4i2yi6 iRBmPyP66kw24gRNkBwBLRii6NNwgi2ikyLww4RNBRiRR2y2 B2LmP4RP2Lg2 wmkLBPB0666Rww yk2wBPB4gwB06w0k","c_data2":"N2g wN6gLNRmwP62iP20mgy0LR4y020RggR 44LRLiy64kLNNNmL B Rk0g6iyRmygyyN4gywNLBmyR00RywP gLBNLkB6m6B0Ni6kwR64Bi0y0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":7,"c_w_id":1,"c_first":"Ny BmL0P","c_middle":"OE","c_last":"BARBARATION","c_street_1":"P6iP24iPN0gRR","c_street_2":"gwkygki2m4RBR42 PB","c_city":"iL46NkiNPg0","c_state":"Rg","c_zip":"610911111","c_phone":"274-326-6928","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4628,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6Pmg y4ygyw RmR22wwBy0PmiRNm4LwB6PmgyimyRmR4LNiNPgLgmPk4 PRk4RkkmP6gRg4P6i g mNw2PBiLRNNgw2g040RR6wyL6 yN 2R6wBLi6LmkBRR m NLRkP2w64L6k6N0LB2 26wgwR2PR4R0g2mkP2m6LkmLi4iyR 64 4 kwg yw2L26wwB4kLwwg40PBkB2ig y Bw LRi0R6 L2Rm044BLPygRRm4600N044NRm6 4","c_data2":"wP0iPgPBBBR4NkLNBB6ByRw6kwPwyNPmmL gPLiL4iwNimgwL4RL6ykgw 2BL2LwN4y0wkk i6P2yNgLRwmyBgwkwwgPkww2PmNLNk4yRg i6i2PPN0k24 0iLN2Li4yRkimL6RyBLwBLL2k0m04mm0kLiygL6y6BRP0ykkRB6y0 2Bg0yyi0B02PwiR6ymmNig04kyLwPL kg 2gwPw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":8,"c_w_id":1,"c_first":"2N BL RL 04y","c_middle":"OE","c_last":"BARBARATION","c_street_1":"P6NN0g gPmL","c_street_2":"26 kwLwwP2y2662 PL","c_city":" yRR6 6iLB4LkB","c_state":" 6","c_zip":"617411111","c_phone":"474-558-2753","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2071,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" gN60RLkkRw2 k6gwR0mmwBwLLm0kPmyigPBB 0Ngigmiy64ywwwR64iyk06B Ng NN0Nky2mNgB42mwLmB0 L4 BwkmLmLLLmiyNyk2BR2kP2NwBRykwwi m gig w0wwm22060LiL2yRkgmL26iL4B0m04iL0NiLLw2y2kmPL mP2BPiygmNiiR0mNgRB24kBNRNyw0kB0PLmP4k4 BPk0PN4 iNLyk 6RimBgLgN6N gyRRRNLL6Nyi","c_data2":"k6mg4gB04ygyRRLBRg2RNRR64600LR2NPPmmNRkg600LLkP2w2Nm P04gyB 42NyLgg44 gRyikBwwwB6NRNNNkP 00LiR2N0gN0y4ygR0L4LN02iRikm60gP2kPiy2NyN NykBNPwk6 B6PB 44Ly4Ri0y2LgPg0Bi6ByRiNyN 2mNkgRm4wLP 0mwP4NBgiRBwLNgB4646NyN2gL4Py y yw2mk0iwy6240L0 02iNP46Pm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":9,"c_w_id":1,"c_first":"yPwBRm4RPBgmy","c_middle":"OE","c_last":"BARBARATION","c_street_1":"2 N0i2B4N6m4L6","c_street_2":"kP2kP6RB0i2LLk44w","c_city":"wBNy20gmNiLP kymBR0","c_state":"Al","c_zip":"822011111","c_phone":"121-143-7689","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0641,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"Pg6mRyRmywy w0w4wyB PPgBkwLkiRL4 kymgRN4k gBg kgmRk46g6N2gm BNN402NwgB4NPyiLw4LBmPk2NwLm PkPBRB RN6Ng0RNw m gmwBk0kPBkiPkR20RRLwNw0N2m6P wg ggiL462BPw2g2RRPPi4NimNy gmB 6yiP4R0LLmiP 2kiLiL4ww424i4m0RygykgByyN6P20wPiww46 N Ng0BwgBk0k2RB6PL4Pm2 PLyP0N","c_data2":"6NRiw6yL2 mRyPB26B04PLk4k wLNg 66 w6gkm6 L iBB2BiN2mR26mPRNgPP4R0gB0LRimN k2PL0NR k66ByLg2Ny2iN0 wB iP2g2R24im6LkkRw Pg 0mL4N2Lm4gm0RgiyRgL6Bg4P6kLww6wRB4PL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":9,"c_d_id":10,"c_w_id":1,"c_first":" mB 40Bg0g","c_middle":"OE","c_last":"BARBARATION","c_street_1":"yg0kBgw6B0kyw6N","c_street_2":"igy2k0 RN40kBm mPiyg","c_city":"L06gN 6BBBLikkwg2mw2","c_state":"22","c_zip":"561411111","c_phone":"410-137-9683","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1955,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mmwgR 4k2g00gLwwyyiNig gNwggw wyPPRig2BigRi4yyyBgRN0Ry064LP6gkLiRBi wiP2m406m 24Nw4i0LR2NRgm gRmwikkmRyL2R4Lg06N BP4y LwyBy kmR426L4kkkg6iwm mwmBmNNPw 0NyNwRgRBiki6Pk2kRwP4NgN NPmNgm4mRiRkBmk2PNwNBNLNmBLg y2wk0w2PN6w6wNNkgL6N RyyyR2BBmLk6y2wyy06w","c_data2":"kwii4BPNP0Lmy0L6g20k2 kBk0 i0k024yBm4wwmNkPLL62mi04ygR2NPmRim0m4wNyB6NmgP2LRRN6Bm6N6PmmmmwLNLB4RmwNLL62BRLmLBP66Ny4k66gL4ik y0N4myiyPBw 0Pm0 R0imB6ikBg 004L0m0 kmm024mPw62yi2BPy ggm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wLimPN6miB6R2BBP46L4k0g2BgB64gmm2w4RmB0w6NNN4RLkPy2k0mNiy NNP 0 k0giN6m kiyig4 66y 4mg4BB 4wNm0w0i4mykwB4 0000 w4B2y46P4LBNPmLLRwPLykkNyB20ywRmPRmL6226yi00kg2y2w6ggL00kNmyg2Rw0y0gNy6LLigg ggii yk44iwiyyi0Rw6 wik 0gPN4mLPmPw4gkBmggL4k46 P0yBkNg 6R6i","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739165,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739165,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":4,"c_w_id":1,"c_first":"BPg0yLwRk","c_middle":"OE","c_last":"BARBAREING","c_street_1":"6wk0N64600 R","c_street_2":"06NRLP0Ryg y6NiR0","c_city":" wLm0 iPyNkmNPmwmB","c_state":"26","c_zip":"851511111","c_phone":"993-592-8926","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1559,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kwBB4B NB R24LRPg042BP4PiPRmygkLiwBiL4kyRgm0yg4L2y0gRmgL60By 40Rgg0RL mB0m6PR wR20Ngw6L 20mPB22Pk0LRN RNRByLLmL2 4mNNRiwk6Lk22kgy4Lwyi44 6BP4NLywPLmim2wwyigNL4NR44 LR4m0 yimggLPRkRiPmLmLBL0RmR2gw4wwggkmNN2RB6giL26Lk2RL60k0yk000wB6wNgB4y0i Nkw wBy4","c_data2":"P2LB BwB2kw LBN0kiRLBwLPwy02iym6wLwB2P kBwkmi igkwRRP0i4RyLLgNyBPw4PkB 4wwk6kRRRP062NR0BP2RBiBw 6g kky6 ky0Pw BBP yN 0mPkwk2imLmwBLBN2kww4LL0P0LBm6Ng0P4RBNim2yR2P44kiLgmmywNkmmRkPiPmww2mmiN LLwwByi 6m6RLPy6PB0 yBiPy6PRN22m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":5,"c_w_id":1,"c_first":"R6LPPm 4gP0N","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 40B0gNi20wBwL","c_street_2":"00RByL6Ry2ykgLP26","c_city":"2LNk2iRRN0yBw","c_state":"i6","c_zip":"359611111","c_phone":"909-504-3037","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3982,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kiky 6w6i iNL06 6NPiBmgk2 2 BBkLRyk4w0R ywwkm04R4kmRgRRkRiB4gBi0m6mRmPPmwkRLmB2 kBkBP2mLPNkN ygLw 0m0mwP0y20Nmm4m6mmL0g00N4RkwNimPNm60kBk4Nw02iBPmywL 4gLg4PL44w gNP 6gkkmPm kR2w4 m44kRL6gkB LgR4 RB RBLN6 N6iwN42wR6kmkRBLgwRwyBNm6Pi4iBRN40Pm0Py262mkR","c_data2":"0kBy0i km RRPgRkNm6yPL04 k42g mki64kBNLw0P2y42202gm0RNkg2B4BPmBPB4L0im2w420Ny gmL 2 imNyB6gkkL0N4ByB PLmgymw0RLmwik0BNyiR06g242L6gN62k2wmPgR6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":6,"c_w_id":1,"c_first":"LB NPR 0","c_middle":"OE","c_last":"BARBAREING","c_street_1":"44gwPwBmiwBiim04wmyg","c_street_2":"yLwByPg2mRgB20mwi","c_city":"yLk444 LB Rk 222BL","c_state":"4w","c_zip":"013811111","c_phone":"910-889-6085","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4218,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iL24N6N0 gkg4kk6k46B66LRwNPBy4PywywL2g4BkN yg0RiLy42yyLLPiPN0LLRkBPkLPkBPNyi6PNBNRBm4kLwNyRmymm2g4R2wBgwPyPRg624m4gi4gN 4BLPB4kyLmiy2BwPBm2gNgw RwwPNRLkiwLNi yBkyP466my2w mmwiiigBRRwikL2 2BPRkmggwmR2Pi0PNNmyLRPwR60ky20P060kBLgmmBmgRRLkPL0N20ByPP2wi06","c_data2":"2 wP00P iR6g2RwRkw ym2mN2RBkimw6Lm22RmLwNRwm44ykPgwkBB0i44w2262i0giNPkPN6g gNw4Bmw6yiy6mw4ywmR0k mP RyPPwPgymikB0wkByPB kR4ywiP2Bii4gy0m y00 62yygRNLiy2wR2k6wPkw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":7,"c_w_id":1,"c_first":" PiwN6LP6R4giP","c_middle":"OE","c_last":"BARBAREING","c_street_1":"yy0wgN 0BwLB","c_street_2":"2 P0y4RN0B","c_city":"26PP6i0y20yiP4PLmNyP","c_state":"Al","c_zip":"767011111","c_phone":"897-842-8196","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.0914,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PNNgm00P6Rkwi6PgBgmP6mLB6wmL6wwkNk2BmLRwi46w4imRBmLL LL0Niw6y0kR6PmPR kLN4gm 0wN0k0g4k4ywm66 wLNByw62mwi2gw B04iPLm2N2myNig m6R6Lw4wP2PNPP R06P0NP62ki4NLN2wBk6g yLmNRm 4imLy60 4Ng4 4L00 mky 4wg220 2kkP0y yi P0 RwL wmRwLL0NkBwiP miy6RR2i P6P44wNB4mi2","c_data2":"26gBmwwm0iLN2w6BiP6wyywBPPR024L4g2Li4imy iRNRNLgLyPPy y R0gkkm6Rwy6iP2w42i Lg4Ny464iLR6ww0w BiL24RBB0igL0ki4m6i6kg4kyy ii4P 60wgwR6yk202gB02yRN4wNR 0i226mN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":8,"c_w_id":1,"c_first":"Bw 2B6k2km4w0BN","c_middle":"OE","c_last":"BARBAREING","c_street_1":"40i 444Liy0B4RL02","c_street_2":"2N246 wBiw 4RNwN04","c_city":"LB262yPP6k B244k4Lw","c_state":"y6","c_zip":"034111111","c_phone":"393-447-7498","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1812,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPN4Bw6N wBgw4w6iP0kw4BwggP240iywRR L4yBLi4Rw2P6m NN R00L2giBLPRBR60RRk2y6NBRPw6Ri4NLi20NwgBNBm 4 g y0P4wkLPwNmwwgkB0P4y2m Lg6igPmL26 wyN0iwkRg4i P4wi6 BRBNgNBgmRBkB2gP 0RkgkwkiP w4wkLiRPyiLgyw2gRg44BR2w2kNPNRN4ByPwg046w0R6g04ykP m0gBBiB0iwyP ggRi4N","c_data2":"2RPiP BymmN4w4R0w22gwgiBN4gg4LLgL2 y6RBwB62R RLLiL0N4ywB02gRLmiy0BL2wm4kP4LRyR0LBwm00BNi26Ng4yB BNgiB2 mRkywyBy6i2ymN0RL0Bi6kg2kk kgR4BNPwN yNgPBk 4wRPN24Bm RLmNR6k2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":9,"c_w_id":1,"c_first":"BiB yLwP6myRN0k0","c_middle":"OE","c_last":"BARBAREING","c_street_1":"kk0P2BPiiykm0 66N0N","c_street_2":"iR4L kN60R2Nm6w4","c_city":"Big2iNkBgmkLPk","c_state":"iy","c_zip":"454211111","c_phone":"429-210-3089","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2704,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6RB4gyRi2ykwBy02R46i ymLLgygi2N62Bigg0NwBNyNBLy0i6wPm0ymN6LmyR RiwL4kPP6m4k y4NL24RNB4mwBk R2 0g42kR600 B0yig NgLkg4PwyB2B6ygg m24gmBi4NNykP6NR 2gR 2wgwNwL4LN624NLLk2mkkwyyygm R0PN4 04mg4P0 mLk26i0RNkPgB4P66y6wy4yBRP4g0BBR40y6RyLg4 ygim22RP0yy0Rgyw","c_data2":"40k R 2 RkmBLmLPLw4NP224i6iN g240gNkL0mPRkgRPym6Pmkkg NwkkNy6 24kg4mPBN2k662L2Pmm0664kN N iRg0mi0k gikNwPwB Lmiw2y62LRmRP4Lm gkiLN4B40kgi6mmL0kLg4w60y6 6yPR6iRyR4mg4R2gLLLwiPRNRLR222 kkRLg4Byym4g4Ri4NR20kykLByyNPPLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":10,"c_d_id":10,"c_w_id":1,"c_first":"RwL0wPBP","c_middle":"OE","c_last":"BARBAREING","c_street_1":"P0wwwPgPwPPmkywL","c_street_2":"2iw2i6Lwy0ig4m040L","c_city":"mg6w wLk y6kPg4","c_state":"g","c_zip":"139611111","c_phone":"226-288-4631","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1072,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"B266gN4LigPRy66wiPLkkRiN2PLPmgk2Pi0wP4iwRNg62N2NmN262mBBm PgNLP62g2PwBBmPg4ym66NN4kLRLggRN6wyBwP4N2PPw44Bm mPNmBNgi0wg6g NNiyLPRgPmwNNgLmB6kNm24gLB6gN244g NRPPP0iw2B44 Rmw42LN402wRR0BN2ykkk004i ymNmBm yBBLkPP w0PiwRy 60BRLRgwRLk04m2w0L 4i2PL24myRgB","c_data2":"0RwRB NgyLRgP4P 4i66PL266LNPPPgN2i6RPkk6P6iiykwNkR646i642 2k02kL6Pg4y6PBi4L2wNgyNymkwki0LP0mPmyNgN2imkBygB6wmLw2yyPy4PB2iN0L2iy42kNPN 0wiPmiRwgw2wgkg0BBPNPLi0NB R6B0L2iyk 2PiPgwwwimBNRP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":430.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":2,"c_w_id":1,"c_first":"NNNmRw Rg","c_middle":"OE","c_last":"BARBAREING","c_street_1":"iwkP0gym40L","c_street_2":"wi6mwmk062i2w2P","c_city":"mw0R L0y 04Rwykmw","c_state":"i2","c_zip":"451711111","c_phone":"555-390-7199","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1694,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iNiwg24BR44m2g6 N2 m6 gP44NP4L6Lw2ywL mmygPymRBBk4wmRmRB44kRP4yiB4wNyiwi6L40BgLB4yikPkywRL0m2RmgP60iBRN0N2LyPN6wLLy2NRyk0w6P N40NmmggLRgyg44R4mmw2wR0RNR6wkiNg6wm0kmgRg0NmgNgy2 L0gNLyBm0iyiiw4B Bik04RNy2ywi24yi00i Bwy0wPBwP6k 4 ykgkLykL6ky NkR6ggiNwR","c_data2":"2RwLkLk2N 40gLmNPwgwkg04BRiPyw06iPRikRygBBg24Nkw2 RBLkwRyBPyw6g0wg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":430.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wLimPN6miB6R2BBP46L4k0g2BgB64gmm2w4RmB0w6NNN4RLkPy2k0mNiy NNP 0 k0giN6m kiyig4 66y 4mg4BB 4wNm0w0i4mykwB4 0000 w4B2y46P4LBNPmLLRwPLykkNyB20ywRmPRmL6226yi00kg2y2w6ggL00kNmyg2Rw0y0gNy6LLigg ggii yk44iwiyyi0Rw6 wik 0gPN4mLPmPw4gkBmggL4k46 P0yBkNg 6R6i","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":4,"c_w_id":1,"c_first":"BPg0yLwRk","c_middle":"OE","c_last":"BARBAREING","c_street_1":"6wk0N64600 R","c_street_2":"06NRLP0Ryg y6NiR0","c_city":" wLm0 iPyNkmNPmwmB","c_state":"26","c_zip":"851511111","c_phone":"993-592-8926","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1559,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kwBB4B NB R24LRPg042BP4PiPRmygkLiwBiL4kyRgm0yg4L2y0gRmgL60By 40Rgg0RL mB0m6PR wR20Ngw6L 20mPB22Pk0LRN RNRByLLmL2 4mNNRiwk6Lk22kgy4Lwyi44 6BP4NLywPLmim2wwyigNL4NR44 LR4m0 yimggLPRkRiPmLmLBL0RmR2gw4wwggkmNN2RB6giL26Lk2RL60k0yk000wB6wNgB4y0i Nkw wBy4","c_data2":"P2LB BwB2kw LBN0kiRLBwLPwy02iym6wLwB2P kBwkmi igkwRRP0i4RyLLgNyBPw4PkB 4wwk6kRRRP062NR0BP2RBiBw 6g kky6 ky0Pw BBP yN 0mPkwk2imLmwBLBN2kww4LL0P0LBm6Ng0P4RBNim2yR2P44kiLgmmywNkmmRkPiPmww2mmiN LLwwByi 6m6RLPy6PB0 yBiPy6PRN22m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":5,"c_w_id":1,"c_first":"R6LPPm 4gP0N","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 40B0gNi20wBwL","c_street_2":"00RByL6Ry2ykgLP26","c_city":"2LNk2iRRN0yBw","c_state":"i6","c_zip":"359611111","c_phone":"909-504-3037","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3982,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kiky 6w6i iNL06 6NPiBmgk2 2 BBkLRyk4w0R ywwkm04R4kmRgRRkRiB4gBi0m6mRmPPmwkRLmB2 kBkBP2mLPNkN ygLw 0m0mwP0y20Nmm4m6mmL0g00N4RkwNimPNm60kBk4Nw02iBPmywL 4gLg4PL44w gNP 6gkkmPm kR2w4 m44kRL6gkB LgR4 RB RBLN6 N6iwN42wR6kmkRBLgwRwyBNm6Pi4iBRN40Pm0Py262mkR","c_data2":"0kBy0i km RRPgRkNm6yPL04 k42g mki64kBNLw0P2y42202gm0RNkg2B4BPmBPB4L0im2w420Ny gmL 2 imNyB6gkkL0N4ByB PLmgymw0RLmwik0BNyiR06g242L6gN62k2wmPgR6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739166,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":6,"c_w_id":1,"c_first":"LB NPR 0","c_middle":"OE","c_last":"BARBAREING","c_street_1":"44gwPwBmiwBiim04wmyg","c_street_2":"yLwByPg2mRgB20mwi","c_city":"yLk444 LB Rk 222BL","c_state":"4w","c_zip":"013811111","c_phone":"910-889-6085","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4218,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"iL24N6N0 gkg4kk6k46B66LRwNPBy4PywywL2g4BkN yg0RiLy42yyLLPiPN0LLRkBPkLPkBPNyi6PNBNRBm4kLwNyRmymm2g4R2wBgwPyPRg624m4gi4gN 4BLPB4kyLmiy2BwPBm2gNgw RwwPNRLkiwLNi yBkyP466my2w mmwiiigBRRwikL2 2BPRkmggwmR2Pi0PNNmyLRPwR60ky20P060kBLgmmBmgRRLkPL0N20ByPP2wi06","c_data2":"2 wP00P iR6g2RwRkw ym2mN2RBkimw6Lm22RmLwNRwm44ykPgwkBB0i44w2262i0giNPkPN6g gNw4Bmw6yiy6mw4ywmR0k mP RyPPwPgymikB0wkByPB kR4ywiP2Bii4gy0m y00 62yygRNLiy2wR2k6wPkw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739166,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739167,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":7,"c_w_id":1,"c_first":" PiwN6LP6R4giP","c_middle":"OE","c_last":"BARBAREING","c_street_1":"yy0wgN 0BwLB","c_street_2":"2 P0y4RN0B","c_city":"26PP6i0y20yiP4PLmNyP","c_state":"Al","c_zip":"767011111","c_phone":"897-842-8196","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.0914,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"PNNgm00P6Rkwi6PgBgmP6mLB6wmL6wwkNk2BmLRwi46w4imRBmLL LL0Niw6y0kR6PmPR kLN4gm 0wN0k0g4k4ywm66 wLNByw62mwi2gw B04iPLm2N2myNig m6R6Lw4wP2PNPP R06P0NP62ki4NLN2wBk6g yLmNRm 4imLy60 4Ng4 4L00 mky 4wg220 2kkP0y yi P0 RwL wmRwLL0NkBwiP miy6RR2i P6P44wNB4mi2","c_data2":"26gBmwwm0iLN2w6BiP6wyywBPPR024L4g2Li4imy iRNRNLgLyPPy y R0gkkm6Rwy6iP2w42i Lg4Ny464iLR6ww0w BiL24RBB0igL0ki4m6i6kg4kyy ii4P 60wgwR6yk202gB02yRN4wNR 0i226mN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739167,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":8,"c_w_id":1,"c_first":"Bw 2B6k2km4w0BN","c_middle":"OE","c_last":"BARBAREING","c_street_1":"40i 444Liy0B4RL02","c_street_2":"2N246 wBiw 4RNwN04","c_city":"LB262yPP6k B244k4Lw","c_state":"y6","c_zip":"034111111","c_phone":"393-447-7498","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1812,"c_balance":1000.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPN4Bw6N wBgw4w6iP0kw4BwggP240iywRR L4yBLi4Rw2P6m NN R00L2giBLPRBR60RRk2y6NBRPw6Ri4NLi20NwgBNBm 4 g y0P4wkLPwNmwwgkB0P4y2m Lg6igPmL26 wyN0iwkRg4i P4wi6 BRBNgNBgmRBkB2gP 0RkgkwkiP w4wkLiRPyiLgyw2gRg44BR2w2kNPNRN4ByPwg046w0R6g04ykP m0gBBiB0iwyP ggRi4N","c_data2":"2RPiP BymmN4w4R0w22gwgiBN4gg4LLgL2 y6RBwB62R RLLiL0N4ywB02gRLmiy0BL2wm4kP4LRyR0LBwm00BNi26Ng4yB BNgiB2 mRkywyBy6i2ymN0RL0Bi6kg2kk kgR4BNPwN yNgPBk 4wRPN24Bm RLmNR6k2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739167,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":9,"c_w_id":1,"c_first":"BiB yLwP6myRN0k0","c_middle":"OE","c_last":"BARBAREING","c_street_1":"kk0P2BPiiykm0 66N0N","c_street_2":"iR4L kN60R2Nm6w4","c_city":"Big2iNkBgmkLPk","c_state":"iy","c_zip":"454211111","c_phone":"429-210-3089","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2704,"c_balance":1000.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"6RB4gyRi2ykwBy02R46i ymLLgygi2N62Bigg0NwBNyNBLy0i6wPm0ymN6LmyR RiwL4kPP6m4k y4NL24RNB4mwBk R2 0g42kR600 B0yig NgLkg4PwyB2B6ygg m24gmBi4NNykP6NR 2gR 2wgwNwL4LN624NLLk2mkkwyyygm R0PN4 04mg4P0 mLk26i0RNkPgB4P66y6wy4yBRP4g0BBR40y6RyLg4 ygim22RP0yy0Rgyw","c_data2":"40k R 2 RkmBLmLPLw4NP224i6iN g240gNkL0mPRkgRPym6Pmkkg NwkkNy6 24kg4mPBN2k662L2Pmm0664kN N iRg0mi0k gikNwPwB Lmiw2y62LRmRP4Lm gkiLN4B40kgi6mmL0kLg4w60y6 6yPR6iRyR4mg4R2gLLLwiPRNRLR222 kkRLg4Byym4g4Ri4NR20kykLByyNPPLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739167,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":null,"after":{"c_id":11,"c_d_id":10,"c_w_id":1,"c_first":"RwL0wPBP","c_middle":"OE","c_last":"BARBAREING","c_street_1":"P0wwwPgPwPPmkywL","c_street_2":"2iw2i6Lwy0ig4m040L","c_city":"mg6w wLk y6kPg4","c_state":"g","c_zip":"139611111","c_phone":"226-288-4631","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1072,"c_balance":1000.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"B266gN4LigPRy66wiPLkkRiN2PLPmgk2Pi0wP4iwRNg62N2NmN262mBBm PgNLP62g2PwBBmPg4ym66NN4kLRLggRN6wyBwP4N2PPw44Bm mPNmBNgi0wg6g NNiyLPRgPmwNNgLmB6kNm24gLB6gN244g NRPPP0iw2B44 Rmw42LN402wRR0BN2ykkk004i ymNmBm yBBLkPP w0PiwRy 60BRLRgwRLk04m2w0L 4i2PL24myRgB","c_data2":"0RwRB NgyLRgP4P 4i66PL266LNPPPgN2i6RPkk6P6iiykwNkR646i642 2k02kL6Pg4y6PBi4L2wNgyNymkwki0LP0mPmyNgN2imkBygB6wmLw2yyPy4PB2iN0L2iy42kNPN 0wiPmiRwgw2wgkg0BBPNPLi0NB R6B0L2iyk 2PiPgwwwimBNRP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739167,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"customer","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739167,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"after":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":43.42,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25531464\"]","schema":"public","table":"customer","txId":4499,"lsn":25531464,"xmin":null},"op":"u","ts_ms":1665511743073,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"after":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":122.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25545544\"]","schema":"public","table":"customer","txId":4500,"lsn":25545544,"xmin":null},"op":"u","ts_ms":1665511743080,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"Al","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"after":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"Al","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":607.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25565208\"]","schema":"public","table":"customer","txId":4501,"lsn":25565208,"xmin":null},"op":"u","ts_ms":1665511743082,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"after":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25585320\"]","schema":"public","table":"customer","txId":4502,"lsn":25585320,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"after":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25608728\"]","schema":"public","table":"customer","txId":4503,"lsn":25608728,"xmin":null},"op":"u","ts_ms":1665511743084,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":43.42,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"after":{"c_id":10,"c_d_id":1,"c_w_id":1,"c_first":"6mgBL0k6mP0LRwL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"k0 gB06B6Ni4","c_street_2":"iRB2P RyLB2 BBB","c_city":"RymkL4Rg0g","c_state":"g0","c_zip":"131311111","c_phone":"540-254-8467","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3853,"c_balance":8788.42,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":2,"c_data1":" B4w6RPBmL2iR4w0yL2NwLiNy2Bmkg2mNig2 PByyL4gwPggN20RBi222g4BNNR2Byk6kgw4Ryw0NigLLgk yN2mkN imNPgL00gLNNy6ki4yi0RBNkiy4mm64yPywLNR602ymyB6NmmP6w m4PP6iwykR4ik2w2w46PR26yLkw2ymyygm6iBgR20w4gwkwB4kP4Nw6PgyPB0wNNNLmPR26NP4Pkg0yRmywN02i RB4iwk RNLwmkP4gyL","c_data2":"66yL0NLm4y60kR4N0 yR62Bmig66RL2B w2wPL22gwNPPgmLN PmkmNBP42BgLBkL4R Li2 0Ni2kNk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25627656\"]","schema":"public","table":"customer","txId":4504,"lsn":25627656,"xmin":null},"op":"u","ts_ms":1665511743085,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":122.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"after":{"c_id":9,"c_d_id":1,"c_w_id":1,"c_first":"6B46gyi4gRB","c_middle":"OE","c_last":"BARBARATION","c_street_1":"Pw4P4ykk wR6Ni42","c_street_2":"RL44B2yBRRm6mLP","c_city":"iiw0Bg2PPBR 42k iw","c_state":"02","c_zip":"239611111","c_phone":"513-596-8472","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2295,"c_balance":122.42,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":2,"c_data1":"wwk66mR6i m004RPgk 0mNgN2L Bm2 mi0iB 0NwRP BLwByNgyB0NkmwwBywwRi26m4gwLBLwywwBkkwmPy6wNB0NgkN2P2NNP4PB0R RB4LmykLPN0gL2i RRkk6iNL RNgkiiimgByNRwR06LLy6LR4mwPgR00kLR4w0wgP4m0BBy4y iL Ngm62R2yyRyR N4wNykw6P2m2LLRB0R2NwwRPLBkgiim44ikmgg6Ny6gwPiNR NNLP6","c_data2":"i4m0LLBi4mL 6Bw66ik2Rimk0i2B2 wLyPwL4ykBRgi2mB4B iRk4k4Bymykm4ywkPLPgN44miNL6mwkwPgmB460RmPk6 R mPP0062kRRL4LNw6wg6BLN0PLB2im4Bm0 w40BL6R6ki6Pi6NmR2gNwBmi44m2gy4y4R6L2BmN0LRRR0R6gkBg P40L64Ng4w 4giL42002wyR006Rw2i60B B46N6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25639096\"]","schema":"public","table":"customer","txId":4505,"lsn":25639096,"xmin":null},"op":"u","ts_ms":1665511743086,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"Al","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":607.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"after":{"c_id":8,"c_d_id":1,"c_w_id":1,"c_first":"Rm2m4mL2LiNL26","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":" k62g mwB6 m","c_street_2":"0mN4Ry4w0mmPRik","c_city":"wLyBmkikB2044","c_state":"Al","c_zip":"226911111","c_phone":"908-531-5952","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4887,"c_balance":607.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":2,"c_data1":"BwwBPP6ky6w4PgP66N mgw0mN0LNP Ri2wym644Pyg4PL6w2k 4By0gBRBkiN6PB04Bkwyi gPk46 R40B4BPmm miBN604N6yRN4R4yPk4 2RN0igm0mPN2wwRy6P 2 y4y B4k4wLP0BNgB2LgNL2B0RwmP R 2P4RRPw4wi440By BymPi0mRLk6gm2Nk0L2RNwR4 PywR4g6Bgi24LyL222L0PL24kkmwLLPg020yk6Ny0ywm6N0yk","c_data2":"kk0gkN6gygLN0kmwi 24 RNB40 k0B64mg4RPwRkRPg B402ym0P6g2gwNNP k0B0i 6N0yiNiNyg NwNB4kyk4PN LiBkgwkRyNgPBBwRBP0yR0wLB 0Ri64w mRw6k N0k2RywgRkP4 RLB k2gBBBmkwy2 2yRyLP6ki4PggPLkk2L42L2w46RwiR20wi2i26R2R4m kN4kwRkN N6LNwLyP4yN6L2yLk6ymk0BkgRm 2k N2NR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25642160\"]","schema":"public","table":"customer","txId":4506,"lsn":25642160,"xmin":null},"op":"u","ts_ms":1665511743088,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"after":{"c_id":7,"c_d_id":1,"c_w_id":1,"c_first":"k62 6R2664LLg","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"60kg26RB60wgBBw24k44","c_street_2":"RyLg4gg4yiBBk0RRRy2","c_city":"m2gkmg4y6 gwLw","c_state":"ii","c_zip":"675311111","c_phone":"705-902-7571","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3822,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":2,"c_data1":"BiPi2iN4LwwR4iLyyw64L64N kg0Bi4gLBkLmN002R4wkPkiNkPkLB4i06Ni2RR2m2mNL0wy6LBi42 Nm wiPg6wB02 BPw2Pk6g44N6460wPPN4Lm2m2iNgyRgR4gwimy 22iNR0g00iRPiyP 2Lgi4kBwLL2N wigiy P20Bm2 B0Pgg02L6NymiL6N6 mNBiNkBkLNBm0gNm iN200NwLk2NLiiy2k 0gym6iwP24RLPkgLN6ii2644","c_data2":"R m ww2LmkyyR4BBRy64wiPymkB0P2gw4gkwkNL6gkPB2RPNkRPLiN RBB m460gRgR2g6PyN224gLkkkmByNw4RyNL6P06RPBw424wNi4wwkm2m0266ywimkNNimmgLRg4y6200ik ikNm22kwiPymP6wR6By 2424yNRBiRy 0m0Ryiw040kiP6y2kBmmP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25654016\"]","schema":"public","table":"customer","txId":4507,"lsn":25654016,"xmin":null},"op":"u","ts_ms":1665511743089,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":1,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"after":{"c_id":6,"c_d_id":1,"c_w_id":1,"c_first":"4 wP0k6iNPg4ik","c_middle":"OE","c_last":"BARBARESE","c_street_1":"4imm2BR2B LBBLy6","c_street_2":"wiy2y4gRB6yky 6 g","c_city":"6P40B6ymRgiP","c_state":"Nm","c_zip":"528611111","c_phone":"298-675-7936","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.485,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":2,"c_data1":"22yww6y2PRBR R6B4gNgiLg0kw0kmk6kL6kwyP4iNPLRk Nyk k4NiiL my6NBRwiyNwNwR4gw2NwkkBm L0NwRRg02iiR44BwPmwL0Ly6w 2y62y24P622kk2420g4Ry g iwN46w46 0Pimy0LmP6yNBBLwiLiRPLiNL2kNmLkiNiL LwNkw6 R6k2NR4L N6PLNg0R g 4 2Pig4BNw0L6B mPwRmLPLym06gyLww42k4PLyB6yw","c_data2":"mPikii4mkBwBBPk6wgmRwm62yNkP2N k6RN6Bg2BB2PwkwN4B2yB6iPL44w24w By 2Lw40y4g262i6BRNRByw4iPB0ByLygkPNmgi wy2giymL046 PgiyN6gBywiimLiwRwmmwg24m0wN64Ni0N RB6RBB2202Lkg k4iLBwBLig6mig20yLmB0kBLR LP6B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25665880\"]","schema":"public","table":"customer","txId":4508,"lsn":25665880,"xmin":null},"op":"u","ts_ms":1665511743090,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"after":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743599,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25806768\",\"25815616\"]","schema":"public","table":"customer","txId":4529,"lsn":25815616,"xmin":null},"op":"u","ts_ms":1665511743607,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"after":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743607,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25816784\",\"25817344\"]","schema":"public","table":"customer","txId":4530,"lsn":25817344,"xmin":null},"op":"u","ts_ms":1665511743611,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":64.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"after":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":22.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743617,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25818776\",\"25827184\"]","schema":"public","table":"customer","txId":4531,"lsn":25827184,"xmin":null},"op":"u","ts_ms":1665511743620,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"after":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743625,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25828544\",\"25837312\"]","schema":"public","table":"customer","txId":4532,"lsn":25837312,"xmin":null},"op":"u","ts_ms":1665511743628,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"after":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743636,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25838640\",\"25839144\"]","schema":"public","table":"customer","txId":4533,"lsn":25839144,"xmin":null},"op":"u","ts_ms":1665511743639,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"after":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743645,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25840304\",\"25840808\"]","schema":"public","table":"customer","txId":4534,"lsn":25840808,"xmin":null},"op":"u","ts_ms":1665511743649,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"after":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743655,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25841968\",\"25842536\"]","schema":"public","table":"customer","txId":4535,"lsn":25842536,"xmin":null},"op":"u","ts_ms":1665511743659,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"after":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743663,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25843904\",\"25844408\"]","schema":"public","table":"customer","txId":4536,"lsn":25844408,"xmin":null},"op":"u","ts_ms":1665511743667,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-10.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"after":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743670,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25845904\",\"25846472\"]","schema":"public","table":"customer","txId":4537,"lsn":25846472,"xmin":null},"op":"u","ts_ms":1665511743674,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":43.0,"c_ytd_payment":10.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"wLimPN6miB6R2BBP46L4k0g2BgB64gmm2w4RmB0w6NNN4RLkPy2k0mNiy NNP 0 k0giN6m kiyig4 66y 4mg4BB 4wNm0w0i4mykwB4 0000 w4B2y46P4LBNPmLLRwPLykkNyB20ywRmPRmL6226yi00kg2y2w6ggL00kNmyg2Rw0y0gNy6LLigg ggii yk44iwiyyi0Rw6 wik 0gPN4mLPmPw4gkBmggL4k46 P0yBkNg 6R6i","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"after":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743680,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25847600\",\"25848104\"]","schema":"public","table":"customer","txId":4538,"lsn":25848104,"xmin":null},"op":"u","ts_ms":1665511743683,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"after":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743687,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25857080\",\"25857712\"]","schema":"public","table":"customer","txId":4539,"lsn":25857712,"xmin":null},"op":"u","ts_ms":1665511743691,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"after":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743696,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25858800\",\"25859304\"]","schema":"public","table":"customer","txId":4540,"lsn":25859304,"xmin":null},"op":"u","ts_ms":1665511743699,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":22.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"after":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-20.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743703,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25860736\",\"25861360\"]","schema":"public","table":"customer","txId":4541,"lsn":25861360,"xmin":null},"op":"u","ts_ms":1665511743706,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"after":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743710,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25862664\",\"25863288\"]","schema":"public","table":"customer","txId":4542,"lsn":25863288,"xmin":null},"op":"u","ts_ms":1665511743714,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"after":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743717,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25864512\",\"25865080\"]","schema":"public","table":"customer","txId":4543,"lsn":25865080,"xmin":null},"op":"u","ts_ms":1665511743721,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"after":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743727,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25866240\",\"25866808\"]","schema":"public","table":"customer","txId":4544,"lsn":25866808,"xmin":null},"op":"u","ts_ms":1665511743730,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"after":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743735,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25867968\",\"25868536\"]","schema":"public","table":"customer","txId":4545,"lsn":25868536,"xmin":null},"op":"u","ts_ms":1665511743738,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"after":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743742,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25869904\",\"25870496\"]","schema":"public","table":"customer","txId":4546,"lsn":25870496,"xmin":null},"op":"u","ts_ms":1665511743746,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-52.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"after":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743750,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25871968\",\"25872536\"]","schema":"public","table":"customer","txId":4547,"lsn":25872536,"xmin":null},"op":"u","ts_ms":1665511743753,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":1.0,"c_ytd_payment":52.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"after":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743757,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25873664\",\"25874232\"]","schema":"public","table":"customer","txId":4548,"lsn":25874232,"xmin":null},"op":"u","ts_ms":1665511743760,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"after":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743764,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25874848\",\"25875416\"]","schema":"public","table":"customer","txId":4549,"lsn":25875416,"xmin":null},"op":"u","ts_ms":1665511743767,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"after":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743771,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25876504\",\"25877072\"]","schema":"public","table":"customer","txId":4550,"lsn":25877072,"xmin":null},"op":"u","ts_ms":1665511743774,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-20.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"after":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-62.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743779,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25878504\",\"25879096\"]","schema":"public","table":"customer","txId":4551,"lsn":25879096,"xmin":null},"op":"u","ts_ms":1665511743782,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"after":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743786,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25880376\",\"25880944\"]","schema":"public","table":"customer","txId":4552,"lsn":25880944,"xmin":null},"op":"u","ts_ms":1665511743789,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"after":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743816,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25882168\",\"25882736\"]","schema":"public","table":"customer","txId":4553,"lsn":25882736,"xmin":null},"op":"u","ts_ms":1665511743819,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"after":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743824,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25883896\",\"25884464\"]","schema":"public","table":"customer","txId":4554,"lsn":25884464,"xmin":null},"op":"u","ts_ms":1665511743827,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"after":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743832,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25885624\",\"25886192\"]","schema":"public","table":"customer","txId":4555,"lsn":25886192,"xmin":null},"op":"u","ts_ms":1665511743835,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"after":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743838,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25887584\",\"25888152\"]","schema":"public","table":"customer","txId":4556,"lsn":25888152,"xmin":null},"op":"u","ts_ms":1665511743841,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-94.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"after":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743846,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25889624\",\"25890192\"]","schema":"public","table":"customer","txId":4557,"lsn":25890192,"xmin":null},"op":"u","ts_ms":1665511743849,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-41.0,"c_ytd_payment":94.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"after":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743852,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25891320\",\"25891888\"]","schema":"public","table":"customer","txId":4558,"lsn":25891888,"xmin":null},"op":"u","ts_ms":1665511743855,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"after":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743860,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25892504\",\"25893232\"]","schema":"public","table":"customer","txId":4559,"lsn":25893232,"xmin":null},"op":"u","ts_ms":1665511743863,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"after":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743868,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25894320\",\"25894888\"]","schema":"public","table":"customer","txId":4560,"lsn":25894888,"xmin":null},"op":"u","ts_ms":1665511743871,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-62.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"after":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-104.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743875,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25896344\",\"25896912\"]","schema":"public","table":"customer","txId":4561,"lsn":25896912,"xmin":null},"op":"u","ts_ms":1665511743879,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"after":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743883,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25898192\",\"25898760\"]","schema":"public","table":"customer","txId":4562,"lsn":25898760,"xmin":null},"op":"u","ts_ms":1665511743886,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"after":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743890,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25899984\",\"25900552\"]","schema":"public","table":"customer","txId":4563,"lsn":25900552,"xmin":null},"op":"u","ts_ms":1665511743893,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"after":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743897,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25901712\",\"25902280\"]","schema":"public","table":"customer","txId":4564,"lsn":25902280,"xmin":null},"op":"u","ts_ms":1665511743900,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"after":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743905,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25903464\",\"25904032\"]","schema":"public","table":"customer","txId":4565,"lsn":25904032,"xmin":null},"op":"u","ts_ms":1665511743909,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"after":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743915,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25905400\",\"25905968\"]","schema":"public","table":"customer","txId":4566,"lsn":25905968,"xmin":null},"op":"u","ts_ms":1665511743920,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-136.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"after":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743926,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25907440\",\"25908008\"]","schema":"public","table":"customer","txId":4567,"lsn":25908008,"xmin":null},"op":"u","ts_ms":1665511743932,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-83.0,"c_ytd_payment":136.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"after":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743938,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25909136\",\"25909704\"]","schema":"public","table":"customer","txId":4568,"lsn":25909704,"xmin":null},"op":"u","ts_ms":1665511743941,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"after":{"c_id":1,"c_d_id":3,"c_w_id":1,"c_first":"yB2Py6k6m","c_middle":"OE","c_last":"BARBARBAR","c_street_1":"NPgBiNwNL0B","c_street_2":"40mmyN4wimy2","c_city":" 4BgRywPyLN 2","c_state":"44","c_zip":"240611111","c_phone":"507-846-7343","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2183,"c_balance":-167.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"i0kR04iB2mLRwPymLiwgRRNykygNi gLmLwik N N06m2RkR6L k6 2NByLBLBkmgRgyw6w6k4mgkyRN6i6i 02g0gigN204gm4mB262 0B606 20Nmykk 4kNkk462BRi6 ikNLyi0Bg wLkBk6gPPkLRB4R44kiBw6iLm0 262NLkR 22NkLk 00 0 wBg6giP06w4gBPRw24466N46PRwPL kLB06PyiRwR4 2PPiyi62k0NLgPBm0","c_data2":"i k6RLgm60wPyBB0PBwigRiP Lggm6PwwmkRiPw24migL40k4w0LgwLgP0PP y2m0ymPLRyNi2BR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743946,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25910320\",\"25910888\"]","schema":"public","table":"customer","txId":4569,"lsn":25910888,"xmin":null},"op":"u","ts_ms":1665511743949,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"after":{"c_id":2,"c_d_id":3,"c_w_id":1,"c_first":"40 giRw0yw i4yR","c_middle":"OE","c_last":"BARBAROUGHT","c_street_1":"mwiyR40gk4","c_street_2":"P2kgwNkPP2ii","c_city":"4i0iBBR N0wmiN4R0k4","c_state":"N2","c_zip":"383111111","c_phone":"557-524-4680","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0833,"c_balance":-167.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g6040PRNRwm6iww gmLgLNP42gNRB4BNBkNN6N4yg 6Nk0y0iPNyigL62yPwLNNN22w kg6B006w RRk6 2LyBNB4LgR 2ggRi gyg0mNy4R0yyR y2wmL22RmR0y6i4R0kimiRwym2i6 R60BgymBN62NBNm0Rk2iB4B4y4kiyw 6y4w4i6NBLNiP4yNi4LgiBmN0w6Ri6i6gR64LgB yBBmw 6Lk4k0L2PLB4Ri4RyymNwN44y 4g62L","c_data2":"06B2N2m40LNgkm LNkymgNR4BR0RwN0ky62g226wgL2B02yyRyi y6w6NPywB4w0NB6gRNwg44 6B6wi gRRN2BmBkkLi6miRBkBL2gm0m 26kP2B4By4N400yg6Rk B wi w 0kB6Nkggm0B6 0k4kkRLNNBmykNRmm4RP62y4Ng6mNkkP6ymL0wg04Lmm4ywyg2i646yy2k6mR4Pw N0iykRLi6Rwg iwk2ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743954,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25912000\",\"25912568\"]","schema":"public","table":"customer","txId":4570,"lsn":25912568,"xmin":null},"op":"u","ts_ms":1665511743957,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-104.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"after":{"c_id":3,"c_d_id":3,"c_w_id":1,"c_first":"LyBkikyL","c_middle":"OE","c_last":"BARBARABLE","c_street_1":"y0wwLL mg0R","c_street_2":"m4LkL02 igLN6ig","c_city":"gkg wykLk6","c_state":"0N","c_zip":"915611111","c_phone":"476-112-9272","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.0847,"c_balance":-146.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":" mRm0LL44ykNkmL4Pi0kNBi0R yL6gPiiBgy 6k0igwB4kmRRy0mwLy4y2N4m2ymRwRwkNmm4m iyLNk P6LwPNm 6N6Bw6NmNym22wLNm42L0Rm Ni6 PgNLLwB646mL2Pk 4PNBLLNgNi4P0k4ikLRR4wgBN PRmBB20kmmRN iiBPP0iB 0wiw0B0666NPmyR2iyB6kg6w26 iw2N4kR6g BPwmR0R642iL i Pik2w6mLy4B6y4wy","c_data2":"mBLRB0g24R6Pgki6 mkkgLPL60LBL kBykN42Py6LBN2PBk6N0NRiB gy6N44myLw06w4L22P264iLL4Rkkm2NB6y4gwi6Liim6NNkgwwL4 imLBgRP yRk2402PP 0g6g iBLk2y0gwy4Bk2y6Rg0RyLimiLLNkmRLB26iyy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743962,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25914000\",\"25914568\"]","schema":"public","table":"customer","txId":4571,"lsn":25914568,"xmin":null},"op":"u","ts_ms":1665511743965,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"after":{"c_id":4,"c_d_id":3,"c_w_id":1,"c_first":"26Ny4PN gLN","c_middle":"OE","c_last":"BARBARPRI","c_street_1":"4BLByN44 R","c_street_2":"i44k6g0PNw gB620","c_city":"ii6PiN2 wPP0","c_state":" 4","c_zip":"431011111","c_phone":"667-598-1822","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.1885,"c_balance":-220.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kkggLmg0k0igkiNL kky0RPR0m kNBRkBw2L0yw06mi0NBRyPwmyk6gRi46BmR26Lg00Nm4giPNLBLL iy404 4RiLLR0N6k2LBwPm0g mP2kRmPNwR0LPiw2B6 BR62NL6LPgP044 k P022gi2R Rg2my6iL PBy6gkRNmyPyB g kP 0iNy2 RPmyRy4 iP2yBNmyy6RygNR62igB4kmB0 ByiPLg2RRmm PB4004iNgmBk4w02 Pw","c_data2":" Likm0 2R22 04kBm2L0ikRkyPPm62Nyk6mN660iRkPygk44m4PBkyki42g460y004gR0402mLPgN 6y0 Pm0LL6mmRPkLyw60LLy2BNLLk ykmR gBmLmLB64L64Rwigk20662Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743969,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25915848\",\"25916416\"]","schema":"public","table":"customer","txId":4572,"lsn":25916416,"xmin":null},"op":"u","ts_ms":1665511743972,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"after":{"c_id":5,"c_d_id":3,"c_w_id":1,"c_first":"y6wwi6y62RPPP6 6","c_middle":"OE","c_last":"BARBARPRES","c_street_1":"m0mB6 BR22 B02","c_street_2":"im mP6R0B6RBPgRPw0kg","c_city":"gPByLmB Nw4mwLBgPy","c_state":"0k","c_zip":"251211111","c_phone":"887-491-3916","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.3224,"c_balance":-220.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"NB6N204RN0iN60wLRkB0 i0Lm4PNPww 2 Byi 2imy0i2LmPiiN00N2ym4P2B yPg6kBLyw Lwyi640Rw24Py PmRgkNmPmBR46By 0B 4ygR LkRyP2LP00kPR0kgi0P0PigmkR6LwPPNmg02w4yP wgBR4mBi00iNNByLiBm 20LmwiLi 6w0ygkkg4mLL 0Py2RmN 6 kLmg2w igLRkmymkg ygy0Biw4mLm2244PBL400P Ly2imm","c_data2":"L24LRBiy6w2RgkNy4iiBPk0 gNB2m64ik426gg2gPgPPRPRw66P0PPm06iPN02gg4 NBNkyNR4PRB6 4LN4ywgy4Rk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743976,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25917640\",\"25918208\"]","schema":"public","table":"customer","txId":4573,"lsn":25918208,"xmin":null},"op":"u","ts_ms":1665511743979,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"after":{"c_id":6,"c_d_id":3,"c_w_id":1,"c_first":"yg0iPi0R0wkgBkmB","c_middle":"OE","c_last":"BARBARESE","c_street_1":"6wR26 6wymLL4yNyi","c_street_2":"2BB6ywiNmNm","c_city":"k0Py46mR 4","c_state":"Ni","c_zip":"633711111","c_phone":"425-871-1957","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4943,"c_balance":-167.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"g4RgRBwR40R4N6RBBwwB4ik y66 4w0wP 6ww0B22N26BR wykiy6L0ggiymLNPP2yL660PiP4B24y4y2mRRmmgi BBmNPk46R6L4 ygP RPiBw22PkNywN mLNw2Nwy PR0B2kwB RPRyL0m42L wPLyyi gw2i4yw Bgy4y k yNy2P4wPkR046i4RBmy4mP4k64yi4ikPykL4RL k0BB0B40R0R64yLL46Ly PwimL0yLRBg w4mw4","c_data2":"RwRyg mB4B606 0R6RN0Bmkiw4wmRiRNR6iw2kg60RLiLwkPk6wygy4y 2wyR4BwiRwByPRNN22B0wmwwLwNL2B2yRmB0im6k4P0mkmg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743983,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25919368\",\"25919960\"]","schema":"public","table":"customer","txId":4574,"lsn":25919960,"xmin":null},"op":"u","ts_ms":1665511743989,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"after":{"c_id":7,"c_d_id":3,"c_w_id":1,"c_first":"Pg0mk22kR4wmP0i","c_middle":"OE","c_last":"BARBARANTI","c_street_1":"6PN2kPL02BiRBki","c_street_2":"w0RB0R22Bk","c_city":"L00wi2iB2R Lw LP2","c_state":"46","c_zip":"539811111","c_phone":"254-684-5865","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2158,"c_balance":-220.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"gPgyPP BP yPgLP462660i 2B2LmByyNPN4LB0PRR2Rm6RP 6 kiB4RLNLwgggP20m6ggw0 60wwRmi ywmP0i4R m Nwwm kBkPyNg0iPB4 NmNmgLm6 iRw240RgR0Pm B0 4Pi6RiLkwL0NRiLPky40LP2 k2wwB460m2wy0LR0Nw y2igkm k0B46RLym44gRiLiRR6yLLwmiN2Lmig wNB4N wmimywikNNkR0Li2iwPkPNi44m2N","c_data2":"4Nmwi66L2yRkB2 R66LRg2w0 wmwLiwNLRR4iL62LNLk0mRNLB22kP2NNy2m44ByiNyyBBiBkim 0Ri04iNBNBy422202g6600mk60ymPLwB0NmP0wmiy6mB4NByByP6y k0LLmRim6ywmm 24wi BR P0Lkgm60yg 0Pg4BgRNB4PLm4P0giim4 wgk2 iBRPP40NyPyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743995,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25921120\",\"25921688\"]","schema":"public","table":"customer","txId":4575,"lsn":25921688,"xmin":null},"op":"u","ts_ms":1665511743999,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"after":{"c_id":8,"c_d_id":3,"c_w_id":1,"c_first":"4P20wkNR4NmRiyLL","c_middle":"OE","c_last":"BARBARCALLY","c_street_1":"mBwwym4kiBgi miiyBB0","c_street_2":"mwggB Nk02","c_city":"wR4PRyBBi2PPwwLRB 44","c_state":"gR","c_zip":"050111111","c_phone":"160-148-3786","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.2933,"c_balance":-167.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"LLm 4mNRNi gP42LgmNBPk0g0L gPNwyLy 6LPiBL yiLmgyi4Nmg0m0PLg NymPyNB4L04 ygg LN00642k4PBik6NgRwk2RR4yywm0 2L4iw2 2 Bm2BPLw 42N2B0imP0 06 yB24mLwPk0 Rm ymgRk2im4 NNiggmiLmLy 6L60BiyLmmPwgPm60iLPk 60 Li066i06iNw60ymL Py 2R0w y4Bw4m64ykk00 yRNBLi44RNmLy","c_data2":"k024g0R kiBm6 NiLkgN4w4P4mBR4wP 6w0gi2iRw44kN0Lkg0 6P 2w4Bg426ygwi4mw0w2BB0myP666RP4wwm4Lig26P i6Rk0NB2Lym4i NR4R064NPNLy2 i6mRgkmB LRgiNk LgLLmiPR PP2Bw iL4 mRRmyBykyN y6wmgN Lmw0g4kBy0N4wNNN0Nw ki6444NkB0B44202kgi6Pkm4Lg4i2Lk6g2PRN2gygLLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744003,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25923056\",\"25923624\"]","schema":"public","table":"customer","txId":4576,"lsn":25923624,"xmin":null},"op":"u","ts_ms":1665511744006,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-178.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"after":{"c_id":9,"c_d_id":3,"c_w_id":1,"c_first":"NNi0L044k 2i0iNP","c_middle":"OE","c_last":"BARBARATION","c_street_1":"i0mNwmPLRiyk 6wiyBi","c_street_2":"2Ry4i6k2P0wm","c_city":"Pw2BLyikP6 iNm0","c_state":"wy","c_zip":"709611111","c_phone":"139-245-6964","c_since":"2015-11-22 00:00:00","c_credit":"GC","c_credit_lim":50000.0,"c_discount":0.4481,"c_balance":-220.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"kNg2PR wiPNyP2wLygk0yiL 6PiygiPyg0L 0LmiiP2BN NwikmNRg0iRNP00m6kw0BLPPyN NyBmgRB0g6L 26446g002BLw L6g wi24iNyw4ky0BgygL 60ygw i2Pi0Nyikm gLgBi gy4BLkygkR 4y Liy0RwLiRNi0kRmgki k02mL0246R 0w6kR0RLgRRPPN0RRNmR2Rmwg4R6wPLP6ym26 m2yR 06g06iLwPR4gPiiwNLP","c_data2":"66LNR2PRmNmk RP iR0 Rw w04 0yLi4NggyL00L0y4N0 0kRBwim4g2i0LRL4wmi6Nk42Rgmgy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744010,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25925096\",\"25925664\"]","schema":"public","table":"customer","txId":4577,"lsn":25925664,"xmin":null},"op":"u","ts_ms":1665511744013,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"c_id"},{"type":"int32","optional":false,"field":"c_d_id"},{"type":"int32","optional":false,"field":"c_w_id"},{"type":"string","optional":true,"field":"c_first"},{"type":"string","optional":true,"field":"c_middle"},{"type":"string","optional":true,"field":"c_last"},{"type":"string","optional":true,"field":"c_street_1"},{"type":"string","optional":true,"field":"c_street_2"},{"type":"string","optional":true,"field":"c_city"},{"type":"string","optional":true,"field":"c_state"},{"type":"string","optional":true,"field":"c_zip"},{"type":"string","optional":true,"field":"c_phone"},{"type":"string","optional":true,"field":"c_since"},{"type":"string","optional":true,"field":"c_credit"},{"type":"float","optional":true,"field":"c_credit_lim"},{"type":"float","optional":true,"field":"c_discount"},{"type":"float","optional":true,"field":"c_balance"},{"type":"float","optional":true,"field":"c_ytd_payment"},{"type":"int32","optional":true,"field":"c_payment_cnt"},{"type":"int32","optional":true,"field":"c_delivery_cnt"},{"type":"string","optional":true,"field":"c_data1"},{"type":"string","optional":true,"field":"c_data2"}],"optional":true,"name":"postgres.public.customer.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.customer.Envelope"},"payload":{"before":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-125.0,"c_ytd_payment":178.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"after":{"c_id":10,"c_d_id":3,"c_w_id":1,"c_first":"0g 00y04i66BRyL","c_middle":"OE","c_last":"BARBAREING","c_street_1":"PBPgyB026i","c_street_2":"Li42iBy0yB iB m","c_city":"PwP2LLNN4kg2NPB4yi","c_state":"RR","c_zip":"057611111","c_phone":"741-153-3745","c_since":"2015-11-22 00:00:00","c_credit":"BC","c_credit_lim":50000.0,"c_discount":0.4823,"c_balance":-167.0,"c_ytd_payment":220.0,"c_payment_cnt":1,"c_delivery_cnt":0,"c_data1":"default","c_data2":"yLLwyPPNy0g 2Lg4m04y46044 ywyw0yRk262igg4PNN26y 2g B0 L0 RkwNBN wRN602"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744018,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25926792\",\"25927360\"]","schema":"public","table":"customer","txId":4578,"lsn":25927360,"xmin":null},"op":"u","ts_ms":1665511744021,"transaction":null}} diff --git a/scripts/source/test_data/district.1 b/scripts/source/test_data/district.1 new file mode 100644 index 0000000000000..fa542d6a3d15f --- /dev/null +++ b/scripts/source/test_data/district.1 @@ -0,0 +1,80 @@ +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":1,"d_w_id":1,"d_name":"PgLwPg","d_street_1":"R6i6Bwi0L6wikNB6wPi","d_street_2":"0NRiwmRgwNyNL2R4m","d_city":"PP2w y2NNLy","d_state":"PB","d_zip":"526711111","d_tax":0.0712,"d_ytd":65355.6,"d_next_o_id":3021},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3011},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52280.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":4,"d_w_id":1,"d_name":"0gByykiLy","d_street_1":"6BLmwwNRBLiR0ig0","d_street_2":"24 wiN04mmNLwmLPRRy","d_city":"yNNBgPw RyN2w240BP","d_state":" w","d_zip":"654011111","d_tax":7.0E-4,"d_ytd":60137.6,"d_next_o_id":3013},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":5,"d_w_id":1,"d_name":"6Nw 4gi","d_street_1":"mNPyggLPR2gi4","d_street_2":"y ig RRLPim","d_city":"4m LR4iP4 BkRw6 P6","d_state":"L2","d_zip":"292511111","d_tax":0.0228,"d_ytd":66315.1,"d_next_o_id":3008},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":6,"d_w_id":1,"d_name":"N4RNiNgPLL","d_street_1":"0LNmw4LBPP","d_street_2":"k0i4mg62w k6wwLwBN6B","d_city":"i04ywLw4LPBm k6PmyR","d_state":"gL","d_zip":"158511111","d_tax":0.1015,"d_ytd":58980.7,"d_next_o_id":3011},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":7,"d_w_id":1,"d_name":"BRBgNigP4R","d_street_1":"gB2Bm0m0gP0wgL2PN","d_street_2":"yiBwgig 0Li6Ngy0N4","d_city":"PP4N42wBPBLwNLPL6yL","d_state":"ii","d_zip":"737511111","d_tax":0.0689,"d_ytd":63425.4,"d_next_o_id":3014},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":8,"d_w_id":1,"d_name":"kR4RmggL","d_street_1":"0ggRi0iB 0","d_street_2":" gg2BygLNR0","d_city":"N2Pi2i6PPBN4ik","d_state":"Ri","d_zip":"340311111","d_tax":0.1599,"d_ytd":60821.2,"d_next_o_id":3016},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":9,"d_w_id":1,"d_name":"PRLii6wwLg","d_street_1":"mNNB2Nw2RLBL6yiN g","d_street_2":"0mNL0yLR wRimB6P2B","d_city":"yyRgk00NkB222PNgwgN","d_state":"w6","d_zip":"323911111","d_tax":0.0292,"d_ytd":38974.5,"d_next_o_id":3018},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":10,"d_w_id":1,"d_name":"0Rggm0","d_street_1":"iNkg4R0g6RB0N","d_street_2":"0iw64R2mNgyL66PN2","d_city":"B60my 0k66BB02BRgm","d_state":"mP","d_zip":"923711111","d_tax":0.121,"d_ytd":54802.7,"d_next_o_id":3013},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739170,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"district","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739170,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3011},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3012},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25671640\"]","schema":"public","table":"district","txId":4509,"lsn":25671640,"xmin":null},"op":"u","ts_ms":1665511743114,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3012},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3013},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25698248\"]","schema":"public","table":"district","txId":4510,"lsn":25698248,"xmin":null},"op":"u","ts_ms":1665511743133,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3013},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3014},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25703528\"]","schema":"public","table":"district","txId":4511,"lsn":25703528,"xmin":null},"op":"u","ts_ms":1665511743157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3014},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3015},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25708744\"]","schema":"public","table":"district","txId":4512,"lsn":25708744,"xmin":null},"op":"u","ts_ms":1665511743179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3015},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3016},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25714024\"]","schema":"public","table":"district","txId":4513,"lsn":25714024,"xmin":null},"op":"u","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3016},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25719240\"]","schema":"public","table":"district","txId":4514,"lsn":25719240,"xmin":null},"op":"u","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3017},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3018},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25724552\"]","schema":"public","table":"district","txId":4515,"lsn":25724552,"xmin":null},"op":"u","ts_ms":1665511743250,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3018},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3019},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25729744\"]","schema":"public","table":"district","txId":4516,"lsn":25729744,"xmin":null},"op":"u","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3019},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3020},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25735056\"]","schema":"public","table":"district","txId":4517,"lsn":25735056,"xmin":null},"op":"u","ts_ms":1665511743358,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3020},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3021},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25740272\"]","schema":"public","table":"district","txId":4518,"lsn":25740272,"xmin":null},"op":"u","ts_ms":1665511743381,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3021},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3022},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25745560\"]","schema":"public","table":"district","txId":4519,"lsn":25745560,"xmin":null},"op":"u","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3022},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3023},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25759464\"]","schema":"public","table":"district","txId":4520,"lsn":25759464,"xmin":null},"op":"u","ts_ms":1665511743427,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3023},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3024},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25764808\"]","schema":"public","table":"district","txId":4521,"lsn":25764808,"xmin":null},"op":"u","ts_ms":1665511743449,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3024},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3025},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25770056\"]","schema":"public","table":"district","txId":4522,"lsn":25770056,"xmin":null},"op":"u","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3025},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3026},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25775336\"]","schema":"public","table":"district","txId":4523,"lsn":25775336,"xmin":null},"op":"u","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3026},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3027},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25780616\"]","schema":"public","table":"district","txId":4524,"lsn":25780616,"xmin":null},"op":"u","ts_ms":1665511743515,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3027},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3028},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25785872\"]","schema":"public","table":"district","txId":4525,"lsn":25785872,"xmin":null},"op":"u","ts_ms":1665511743534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3028},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3029},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25791152\"]","schema":"public","table":"district","txId":4526,"lsn":25791152,"xmin":null},"op":"u","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3029},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3030},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25796408\"]","schema":"public","table":"district","txId":4527,"lsn":25796408,"xmin":null},"op":"u","ts_ms":1665511743570,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3030},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3031},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25801688\"]","schema":"public","table":"district","txId":4528,"lsn":25801688,"xmin":null},"op":"u","ts_ms":1665511743593,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52280.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52322.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743599,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25806768\",\"25807280\"]","schema":"public","table":"district","txId":4529,"lsn":25807280,"xmin":null},"op":"u","ts_ms":1665511743606,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52322.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52364.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743607,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25816784\",\"25817032\"]","schema":"public","table":"district","txId":4530,"lsn":25817032,"xmin":null},"op":"u","ts_ms":1665511743611,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52364.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52406.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743617,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25818776\",\"25819024\"]","schema":"public","table":"district","txId":4531,"lsn":25819024,"xmin":null},"op":"u","ts_ms":1665511743620,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52406.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52448.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743625,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25828544\",\"25828792\"]","schema":"public","table":"district","txId":4532,"lsn":25828792,"xmin":null},"op":"u","ts_ms":1665511743628,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52448.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52490.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743636,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25838640\",\"25838888\"]","schema":"public","table":"district","txId":4533,"lsn":25838888,"xmin":null},"op":"u","ts_ms":1665511743639,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52490.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52532.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743645,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25840304\",\"25840552\"]","schema":"public","table":"district","txId":4534,"lsn":25840552,"xmin":null},"op":"u","ts_ms":1665511743649,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52532.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52574.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743655,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25841968\",\"25842216\"]","schema":"public","table":"district","txId":4535,"lsn":25842216,"xmin":null},"op":"u","ts_ms":1665511743658,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52574.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52616.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743663,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25843904\",\"25844152\"]","schema":"public","table":"district","txId":4536,"lsn":25844152,"xmin":null},"op":"u","ts_ms":1665511743667,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52616.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52658.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743670,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25845904\",\"25846152\"]","schema":"public","table":"district","txId":4537,"lsn":25846152,"xmin":null},"op":"u","ts_ms":1665511743674,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52658.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52700.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743680,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25847600\",\"25847848\"]","schema":"public","table":"district","txId":4538,"lsn":25847848,"xmin":null},"op":"u","ts_ms":1665511743683,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52700.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52742.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743687,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25857080\",\"25857328\"]","schema":"public","table":"district","txId":4539,"lsn":25857328,"xmin":null},"op":"u","ts_ms":1665511743691,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52742.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52784.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743696,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25858800\",\"25859048\"]","schema":"public","table":"district","txId":4540,"lsn":25859048,"xmin":null},"op":"u","ts_ms":1665511743699,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52784.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52826.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743703,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25860736\",\"25860984\"]","schema":"public","table":"district","txId":4541,"lsn":25860984,"xmin":null},"op":"u","ts_ms":1665511743706,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52826.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52868.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743710,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25862664\",\"25862912\"]","schema":"public","table":"district","txId":4542,"lsn":25862912,"xmin":null},"op":"u","ts_ms":1665511743714,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52868.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52910.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743717,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25864512\",\"25864760\"]","schema":"public","table":"district","txId":4543,"lsn":25864760,"xmin":null},"op":"u","ts_ms":1665511743721,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52910.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52952.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743727,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25866240\",\"25866488\"]","schema":"public","table":"district","txId":4544,"lsn":25866488,"xmin":null},"op":"u","ts_ms":1665511743730,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52952.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52994.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743735,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25867968\",\"25868216\"]","schema":"public","table":"district","txId":4545,"lsn":25868216,"xmin":null},"op":"u","ts_ms":1665511743738,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52994.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53036.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743742,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25869904\",\"25870152\"]","schema":"public","table":"district","txId":4546,"lsn":25870152,"xmin":null},"op":"u","ts_ms":1665511743746,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53036.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53078.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743750,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25871968\",\"25872216\"]","schema":"public","table":"district","txId":4547,"lsn":25872216,"xmin":null},"op":"u","ts_ms":1665511743753,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53078.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53120.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743757,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25873664\",\"25873912\"]","schema":"public","table":"district","txId":4548,"lsn":25873912,"xmin":null},"op":"u","ts_ms":1665511743760,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53120.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53162.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743764,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25874848\",\"25875096\"]","schema":"public","table":"district","txId":4549,"lsn":25875096,"xmin":null},"op":"u","ts_ms":1665511743767,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53162.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53204.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743771,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25876504\",\"25876752\"]","schema":"public","table":"district","txId":4550,"lsn":25876752,"xmin":null},"op":"u","ts_ms":1665511743774,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53204.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53246.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743779,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25878504\",\"25878776\"]","schema":"public","table":"district","txId":4551,"lsn":25878776,"xmin":null},"op":"u","ts_ms":1665511743782,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53246.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53288.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743786,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25880376\",\"25880624\"]","schema":"public","table":"district","txId":4552,"lsn":25880624,"xmin":null},"op":"u","ts_ms":1665511743789,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53288.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53330.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743816,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25882168\",\"25882416\"]","schema":"public","table":"district","txId":4553,"lsn":25882416,"xmin":null},"op":"u","ts_ms":1665511743818,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53330.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53372.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743824,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25883896\",\"25884144\"]","schema":"public","table":"district","txId":4554,"lsn":25884144,"xmin":null},"op":"u","ts_ms":1665511743827,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53372.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53414.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743832,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25885624\",\"25885872\"]","schema":"public","table":"district","txId":4555,"lsn":25885872,"xmin":null},"op":"u","ts_ms":1665511743835,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53414.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53456.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743838,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25887584\",\"25887832\"]","schema":"public","table":"district","txId":4556,"lsn":25887832,"xmin":null},"op":"u","ts_ms":1665511743841,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53456.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53498.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743846,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25889624\",\"25889872\"]","schema":"public","table":"district","txId":4557,"lsn":25889872,"xmin":null},"op":"u","ts_ms":1665511743849,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53498.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53540.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743852,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25891320\",\"25891568\"]","schema":"public","table":"district","txId":4558,"lsn":25891568,"xmin":null},"op":"u","ts_ms":1665511743855,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53540.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53582.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743860,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25892504\",\"25892752\"]","schema":"public","table":"district","txId":4559,"lsn":25892752,"xmin":null},"op":"u","ts_ms":1665511743863,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53582.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53624.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743868,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25894320\",\"25894568\"]","schema":"public","table":"district","txId":4560,"lsn":25894568,"xmin":null},"op":"u","ts_ms":1665511743871,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53624.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53666.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743875,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25896344\",\"25896592\"]","schema":"public","table":"district","txId":4561,"lsn":25896592,"xmin":null},"op":"u","ts_ms":1665511743879,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53666.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53708.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743883,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25898192\",\"25898440\"]","schema":"public","table":"district","txId":4562,"lsn":25898440,"xmin":null},"op":"u","ts_ms":1665511743886,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53708.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53750.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743890,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25899984\",\"25900232\"]","schema":"public","table":"district","txId":4563,"lsn":25900232,"xmin":null},"op":"u","ts_ms":1665511743893,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53750.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53792.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743897,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25901712\",\"25901960\"]","schema":"public","table":"district","txId":4564,"lsn":25901960,"xmin":null},"op":"u","ts_ms":1665511743900,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53792.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53834.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743905,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25903464\",\"25903712\"]","schema":"public","table":"district","txId":4565,"lsn":25903712,"xmin":null},"op":"u","ts_ms":1665511743909,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53834.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53876.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743915,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25905400\",\"25905648\"]","schema":"public","table":"district","txId":4566,"lsn":25905648,"xmin":null},"op":"u","ts_ms":1665511743920,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53876.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53918.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743926,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25907440\",\"25907688\"]","schema":"public","table":"district","txId":4567,"lsn":25907688,"xmin":null},"op":"u","ts_ms":1665511743932,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53918.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53960.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743938,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25909136\",\"25909384\"]","schema":"public","table":"district","txId":4568,"lsn":25909384,"xmin":null},"op":"u","ts_ms":1665511743941,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":53960.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54002.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743946,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25910320\",\"25910568\"]","schema":"public","table":"district","txId":4569,"lsn":25910568,"xmin":null},"op":"u","ts_ms":1665511743949,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54002.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54044.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743954,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25912000\",\"25912248\"]","schema":"public","table":"district","txId":4570,"lsn":25912248,"xmin":null},"op":"u","ts_ms":1665511743957,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54044.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54086.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743962,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25914000\",\"25914248\"]","schema":"public","table":"district","txId":4571,"lsn":25914248,"xmin":null},"op":"u","ts_ms":1665511743965,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54086.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54128.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743969,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25915848\",\"25916096\"]","schema":"public","table":"district","txId":4572,"lsn":25916096,"xmin":null},"op":"u","ts_ms":1665511743972,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54128.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54170.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743976,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25917640\",\"25917888\"]","schema":"public","table":"district","txId":4573,"lsn":25917888,"xmin":null},"op":"u","ts_ms":1665511743979,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54170.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54212.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743983,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25919368\",\"25919640\"]","schema":"public","table":"district","txId":4574,"lsn":25919640,"xmin":null},"op":"u","ts_ms":1665511743989,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54212.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54254.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743995,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25921120\",\"25921368\"]","schema":"public","table":"district","txId":4575,"lsn":25921368,"xmin":null},"op":"u","ts_ms":1665511743999,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54254.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54296.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744003,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25923056\",\"25923304\"]","schema":"public","table":"district","txId":4576,"lsn":25923304,"xmin":null},"op":"u","ts_ms":1665511744006,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54296.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54338.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744010,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25925096\",\"25925344\"]","schema":"public","table":"district","txId":4577,"lsn":25925344,"xmin":null},"op":"u","ts_ms":1665511744013,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54338.5,"d_next_o_id":3017},"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":54380.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744018,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25926792\",\"25927040\"]","schema":"public","table":"district","txId":4578,"lsn":25927040,"xmin":null},"op":"u","ts_ms":1665511744021,"transaction":null}} diff --git a/scripts/source/test_data/item.1 b/scripts/source/test_data/item.1 new file mode 100644 index 0000000000000..d06ce5d4fb36c --- /dev/null +++ b/scripts/source/test_data/item.1 @@ -0,0 +1,1500 @@ +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1,"i_im_id":7640,"i_name":"9MV8yNk6CYTlmgbdQrsmLb","i_price":53.92,"i_data":"WcOVgbFZXLdEoqMDCoCmFKgI0FIvXj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739173,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739173,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":2,"i_im_id":2416,"i_name":"NsKTnVQ542CLpJfORRu","i_price":19.84,"i_data":"hzkM0hKktwmFspYg0huCf4vOc96ZyP6Vu8Zk8Jmjbfu8g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739173,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":3,"i_im_id":1907,"i_name":"AprMxezhKQkiI90","i_price":95.36,"i_data":"76f6QxIUWlSUVoB1Iomc90Lpir97k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":4,"i_im_id":6193,"i_name":"6D7RVkgWk2bnmhsrBn5SgAgR","i_price":14.55,"i_data":"FrXbxyGxsDBHVUENED9jp40eTnZyDWUlHQZVHtvpKdLkBDgcQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":5,"i_im_id":3278,"i_name":"R6le82FzuhFP32ErHkToRZ","i_price":4.95,"i_data":"bHIQ5Lyttp4EMMjgWfsIUovxATW8eolbLSb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":6,"i_im_id":4134,"i_name":"Qui5WxWbdp1oIFfLzMQfA","i_price":8.9,"i_data":"Q9N51Cet4qRt3NhintuvvK5QAe9pEnzYM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":7,"i_im_id":1131,"i_name":"5xZF9H7wXuwQah6ozG8","i_price":52.68,"i_data":"AafzYSeAunImynOFm03oHNueZKKPGWQxQ4yELSFhSZLT7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":8,"i_im_id":8715,"i_name":"jnd7RfZQrtwO4ZkhS","i_price":51.71,"i_data":"AXwfABoLSbrh59d44zT70co0dSYXwiZpPPGUQu1k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":9,"i_im_id":7848,"i_name":"5efu0qAiUFVuxxSwptHl","i_price":48.74,"i_data":"TcnKoMmYoriginal1ucckgw3hVGn5xK0ZZnhW3n2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739174,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":10,"i_im_id":2250,"i_name":"S00J06OqTyeNoGLKbu3G7","i_price":18.06,"i_data":"0JeFJY2sxiEM6TGDEEXjsSlwYCGXGcyQNOH24MNvuS3Q8gK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":11,"i_im_id":4246,"i_name":"t4ccklaRBqjFXhCnH","i_price":49.72,"i_data":"coAXcc6UY3Qv2QUKXrJcDxbPBN22A64KVpXeIhyrPkyjBB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":12,"i_im_id":3506,"i_name":"ddy7faiV2W5bru6bBjNBh","i_price":45.05,"i_data":"L4ZYT0usq2p0M57kd1cy5tpwFHzmo87BmHQyM82mP7B4G"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":13,"i_im_id":9765,"i_name":"ed8L2wdxiNc86DSg7xmOGM","i_price":89.53,"i_data":"F92HKBSzw566xMSbYnlf6ZD5vK4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":14,"i_im_id":5595,"i_name":"VykD7LWaVxr5VyT","i_price":82.57,"i_data":"6ZlQZhGmfvEcml80UHidXCo8BMoFNyIqCRBx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":15,"i_im_id":1807,"i_name":"nTKqRKLVCtEAZHFRXGP","i_price":81.28,"i_data":"ZAUdlLZXYgudzsD5M9eqSyMXtkWGAGltI4YSPr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":16,"i_im_id":1471,"i_name":"VW5kltBFr8lPZ8JxIHIDTJS","i_price":85.02,"i_data":"x2JhA6IFHtIociSZHTZzMBUKqMOYlFlE47Pdtg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":17,"i_im_id":7309,"i_name":"L2hwVRboEbZ2hPb59vDasXF","i_price":92.22,"i_data":"PCKaNXtwhfrH0X1CZqTjoOpdzuy67dA1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":18,"i_im_id":9318,"i_name":"UGZhySIbfZYlL1NTkvhEK","i_price":67.88,"i_data":"0wi06wnmZxGIVka3XaCBji0qpUfcQIcSafIODojHblfy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":19,"i_im_id":6740,"i_name":"kFwUJDVs8PUitVIbTccVLCsQ","i_price":19.66,"i_data":"Gh5ZjYQMvZacArBdS960yybZ8tYI2OsdwhVCtcERK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":20,"i_im_id":5404,"i_name":"6q3dxALZj0gBIt","i_price":14.25,"i_data":"CFwUDAvvpd1ejPrWgqyYzbVJf5m3IPm6EevqCxwwax"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":21,"i_im_id":9974,"i_name":"HvGYq9LUleLAYUcpASlD","i_price":58.19,"i_data":"xtuVpPCQmw1vJRu7tXBwwH6hdHR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":22,"i_im_id":2636,"i_name":"UYEAx0mOuNpQJGjZ","i_price":99.73,"i_data":"rRR4WWgexgkh4DnuHMDyHvWZaKGqLY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":23,"i_im_id":612,"i_name":"NwJuCQLeCrcbbc3","i_price":88.22,"i_data":"3YYUJlXvzPzRQQWrbub8W23WhAJiCwyblSmgGEeft3U6XB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":24,"i_im_id":908,"i_name":"a8ieSTL7yDEet1","i_price":95.35,"i_data":"fqtegNN73QoiUdImlGJbWUiPK3E58TgZ84yI97deYABl7YYP9z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":25,"i_im_id":3167,"i_name":"zY76m194yqaEKSZ027ZiaHfL","i_price":61.72,"i_data":"CI89Bag4P0OH8OiJoriginalhni"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":26,"i_im_id":1011,"i_name":"KDUNHnfBPw0yGG","i_price":31.03,"i_data":"0ulF5HJqYnOnsWIHMtItbWUFNChk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":27,"i_im_id":9746,"i_name":"RBQCVWthwHFGvSOGTFrMNKiq","i_price":55.51,"i_data":"CY45cPY8XeUX4rMIC7QOt52SLIsO7jKjIjiFocJZdT1pETv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":28,"i_im_id":4094,"i_name":"ZyBzM3RXghCJe8wPbxO6Dj","i_price":32.44,"i_data":"54NYD1YuJoLp6gEUTUSQ0nHys1EaXH0oCWf0DCH4fHrTCH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739175,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":29,"i_im_id":4168,"i_name":"fBKFpYmbTSCurZwIBSC","i_price":81.05,"i_data":"M3CNkebfW6VfTBqzp4oFVrnoi1XHBIm7l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":30,"i_im_id":5431,"i_name":"tPBmfeclv9j6dVjMkiJj2X","i_price":86.19,"i_data":"2B145W1tAQ53NPcoej0tyo4OsjUSumXb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":31,"i_im_id":8524,"i_name":"xA3ZZPZGPZz4CpmIZb2pY4","i_price":93.5,"i_data":"iBdBckhQttytKn2qFIxERI8u7PTEoriginal3b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":32,"i_im_id":5755,"i_name":"vWYJvMIPGkAHP60zlW","i_price":85.84,"i_data":"nv3TEzNKsoPxSRXm7iE4NCRBBOU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":33,"i_im_id":6139,"i_name":"tEdzF8kghiu0yyZJ0","i_price":75.3,"i_data":"lAOsdmuF5g4hWIUOF4ygI8tKvimg7rkggemD3rWTr4PxklBxb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":34,"i_im_id":7469,"i_name":"L1AX0HxaeQwNJpaB","i_price":41.5,"i_data":"op9EH5ZVAuXMGydYNrk38HiB3d6ORZVXtGgB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":35,"i_im_id":4669,"i_name":"Ru6QVmdahoaIKo","i_price":38.45,"i_data":"dnoPFHVyIjyfP5z1yTRb2mHtiL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":36,"i_im_id":2978,"i_name":"4ITYwi7mC1gSZvxweyBEOBan","i_price":84.87,"i_data":"ZVHTrLRKBrTIU82rsO2qZIeUypg3wb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":37,"i_im_id":9049,"i_name":"ssHSCI7qRGVoaarb79KXz4ob","i_price":61.93,"i_data":"K6MXVY6GrNkCSikRcgBdzNVq4QG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":38,"i_im_id":7243,"i_name":"RiVtvCwEiwt0N9OnBwyVwMt","i_price":26.52,"i_data":"TrE0cwI0GDSzlGIt7LUGbJfj22tXvioGSGhZFqpKW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":39,"i_im_id":6019,"i_name":"HBEKMzlxUSdweOlMTQ6BXVx","i_price":77.76,"i_data":"6sJ44NloUTsHb7NbtH9jv5CQmjs7si7gKyRYGLfkFnLSomwQr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":40,"i_im_id":3927,"i_name":"JPxjefMXcHxMhHGlnKhP0j5","i_price":83.75,"i_data":"hCrdDAJdLFa4gbRw6fbjgfOTj2zvcgjAvurhk0Iu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":41,"i_im_id":252,"i_name":"Y8TnSiabnr1jbri","i_price":76.12,"i_data":"lp1KOMrSg4EUGLVmDYQsZMTLNzgUT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":42,"i_im_id":1679,"i_name":"zd84PS7RDAWhYJ","i_price":20.37,"i_data":"BaV0p1CEW2originalxz0y7QhDw03298"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":43,"i_im_id":5585,"i_name":"mX4gJhDnsTkARcg","i_price":36.96,"i_data":"s8kDRXld1YUOkBly3MK9epkDw2ADmCUKuiOMdjGNZ27Uqhi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":44,"i_im_id":248,"i_name":"dbS4HiRkxXxsqFArX","i_price":76.76,"i_data":"Od1GoNfGBLIfsNMm8RB4DtYVvHJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":45,"i_im_id":2994,"i_name":"p3RrlAVpzgYG8j0C","i_price":89.77,"i_data":"CEXG9iZJKa89OFDi64AXwt2kH5YyYQKzyFsf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":46,"i_im_id":3522,"i_name":"t5coKomHaPANbfKiy2VXtL","i_price":69.49,"i_data":"4xQKBCPjzRlyHGQrXtKfFC72toerMjRe04uGHapjyjvXEm2s2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":47,"i_im_id":7066,"i_name":"f03TYXbdYkqz6kveKs9","i_price":96.71,"i_data":"Xm0MH27Vka7jLplL7bECWMKcIB3MxIdbjBLLRyOA5UNfh92LGk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":48,"i_im_id":4301,"i_name":"4Ll23jur0FD4nAjh","i_price":39.4,"i_data":"2YzsYhlcjrlfKGUuogMGygyt7IvUGG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":49,"i_im_id":2997,"i_name":"1gc8yvClZUNzUVOtXIUxO","i_price":17.67,"i_data":"8DOLfXyOFqLShG5EJl7JdZWDyQPxS3YlkNv0b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739176,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":50,"i_im_id":922,"i_name":"pVRJAXJWxBDOPwHyZKs7INB","i_price":10.03,"i_data":"cj6CQZDv1huZfZhCfZXSjdc37o4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":51,"i_im_id":5759,"i_name":"W6i2UCUaelSzr2lGL9Ts5","i_price":34.59,"i_data":"RymNxrO34ZrQBGYhV5Agqj7OkaVdRJIAroMuTbQyz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":52,"i_im_id":6472,"i_name":"7i3AtnvkRInMqRLgS6c1lUn","i_price":76.58,"i_data":"lcf5LO5VU8Zuk4UXoy8YoyV7N7elj6niB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":53,"i_im_id":8711,"i_name":"ecP3AI7w4yVvwk5","i_price":42.52,"i_data":"zLLm7B7owwcusWXmcSbYoLQ5UE9xu41kKb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":54,"i_im_id":2132,"i_name":"ct9kDgus7GwujDa9njCon2S","i_price":8.04,"i_data":"gnF9fIXZxVdoriginalamUJucB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":55,"i_im_id":9254,"i_name":"77UlRl9uiYm7oe1gDqAleq","i_price":7.5,"i_data":"QrfV75grkC16XopZHkM5HAwujL0b29aSjGaONjLPH8R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":56,"i_im_id":6335,"i_name":"hU8wE9aFQL1JBTCP","i_price":84.82,"i_data":"2hN0m6GPtfmdNmAaZOBZmNKcjv2zx9znvl71np9HRkL6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":57,"i_im_id":8461,"i_name":"sj5Xr7qzw35utX","i_price":25.68,"i_data":"yoCtaDAGklsqoIJDUQ5KSBn7xymIU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":58,"i_im_id":8551,"i_name":"GxTE4TZEdPiuB6N9mOCQB","i_price":25.21,"i_data":"dmoG2ASxBGej0qelsaVwSnfZtfVFBbzkZY9cdtfmUbi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":59,"i_im_id":3991,"i_name":"eOYP8MztMrQ3kE5BgBA","i_price":34.49,"i_data":"Bdx2GqH16Lb8aldV7Xtpa3lYK9Wso82EewJ8qDuLi2EmJxed3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":60,"i_im_id":5528,"i_name":"SuMKUpks20MVLNw2gc","i_price":82.91,"i_data":"DQKHtOSrJq1eLwv3Pexm4yDh1yklSsfyy5aA5fVSyb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":61,"i_im_id":3091,"i_name":"PGjlCUTKvUARyWdB","i_price":26.42,"i_data":"k2XDc0KI5etKAnbFy6uNUhAGVxadw7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":62,"i_im_id":9634,"i_name":"eoNmcZZAlKPuIG5KFgn","i_price":26.27,"i_data":"coAXcc6UY3Qv2QUKXrJcDxbPBN22A64KVpXeIhyrPkyjBB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":63,"i_im_id":586,"i_name":"lncie89pstAvCdIw7c","i_price":46.95,"i_data":"cxLMpbMBSyXL1y5bRnnkrKlgDzDmYuJb4S91Ey9zdOtRk9b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":64,"i_im_id":7790,"i_name":"Z9W0VIzTcJlyBt8n","i_price":22.7,"i_data":"2viAq8UU3Rvv9BZMOp0WOrFbu8wB5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":65,"i_im_id":2983,"i_name":"FocqCYqnoXH10QFlFlyAM","i_price":19.52,"i_data":"Xnq6qfeUzYeZlaoYTKkQnBruFmO0cy2CHpvCmWFVAZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":66,"i_im_id":9624,"i_name":"Ap9fxOb4BgatnhrOYd","i_price":85.44,"i_data":"Jhn9ajicafSZ3DTGvdKKXIVVnj9FxlSFlMz9D1c4xt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":67,"i_im_id":9317,"i_name":"WGOgGNKUI9rJ8IOAjb6iQkc","i_price":7.53,"i_data":"PUQpIRfyEnjc4oAvVHVzhAUy0cX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":68,"i_im_id":3081,"i_name":"WNU6OrQQ3HKAyoQ8c7","i_price":95.79,"i_data":"OHMq9LTyviJo4mFTmkoBkDiD14VVymNfz2mRncSoK4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739177,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":69,"i_im_id":138,"i_name":"tf9IkWLlXKssLH","i_price":72.18,"i_data":"dSEvR0dL0WN3i9CwcSfaT1K8UQWIiTVyxEEeOltjYZ4CpgQ6I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":70,"i_im_id":2409,"i_name":"eFZxoCg67FkKJUSGuU","i_price":83.56,"i_data":"usfKrIqsRCN46loSI8I8KLYKedVfO0miCuvnLCVxfb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":71,"i_im_id":2943,"i_name":"TM76uaNv4HFty3dNT","i_price":94.57,"i_data":"5MSOfJnH1jpY27kjxsyIxZafsPG3fgdLR4fCNWhsPZKM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":72,"i_im_id":5470,"i_name":"6Iw1USG8emyFZmjUc","i_price":47.98,"i_data":"GBvkjPNilhrJIXyuS7uFqIZjIBLKawAUiy7u"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":73,"i_im_id":5687,"i_name":"OEDrGN6OTv6vhQHp1Tkc4myA","i_price":85.93,"i_data":"50ZCkWkZK2BUAlSpE0nLCx7aSSosFu2zc5j0vsdBdfsQl5aTz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":74,"i_im_id":5763,"i_name":"L1FJOUA1VzjbgJ","i_price":13.78,"i_data":"icCOrHesHfkIzue5kNYY2Eequ9ZuR5k9Bqj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":75,"i_im_id":5500,"i_name":"0XuK2i7G2ygK5P","i_price":68.18,"i_data":"vfznJv7sQpshbMUife6Px2RgHIZAYVDb4Vj8uyZSN4lj83b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":76,"i_im_id":6206,"i_name":"H9CkWXT1pJzsSFec","i_price":10.04,"i_data":"tuFyQ6hy94Bxe3THpkoBoSXrJw5nOC9IXOYwb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":77,"i_im_id":816,"i_name":"IwEzkofJ3AEyzEynqGYM2KeW","i_price":92.6,"i_data":"JaAOjv8dsIFkWvu3Towhs8kXJC1rd6Q1DvtGvm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":78,"i_im_id":5177,"i_name":"zXcDPC1sQRwiXKICxW","i_price":25.92,"i_data":"MMNDn1sL0XOwF30cqCGU0jsneoLmbemJCbT0c1ZEpdONCPi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":79,"i_im_id":5556,"i_name":"R9UtaZjUQzLToiQbSRGHK","i_price":41.66,"i_data":"TxCTaJBjgXX3QgB3faQyYknBY89ahL0Jn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":80,"i_im_id":691,"i_name":"sDInbdYgzmGPxpJLSrxdO","i_price":53.08,"i_data":"X8Oi8VYCz32tC3GMWqfURDzMZ5S4iU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":81,"i_im_id":7810,"i_name":"YoAWyfqDO2zlfNM9fRDg","i_price":61.78,"i_data":"4L0DvONR5MRHBPorP9c78PJsF6pr6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":82,"i_im_id":1758,"i_name":"9q6R7WHCEtrSGpDqESIYHHo","i_price":42.96,"i_data":"VZum3GSAmfgKCKSS28aWKpaf1RwiLeFXhKYMXHza21em"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":83,"i_im_id":8227,"i_name":"1XIAa19ulNozTHw","i_price":65.16,"i_data":"34mr90XTjqdR8UUyXpZ1ra5AIvDEG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":84,"i_im_id":5711,"i_name":"1nCV8NcKQjn0BUMqh","i_price":42.49,"i_data":"mJQR654rNYCJPHY8gtTzsXraHnJQdEbx6b6KyKpkJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":85,"i_im_id":3729,"i_name":"QYwbI89e9ncnlJOJ9oM","i_price":18.5,"i_data":"6kBReScWflnpkixuCtOhsfjk9k10kAHBv9GxEhI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":86,"i_im_id":7130,"i_name":"Nl979aeBArbokbg6KalMkm","i_price":24.54,"i_data":"b0QRWXtjEnyONUUziM1maBLBoriginalzu0JlGJEefoJN8SVg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":87,"i_im_id":3026,"i_name":"j5DAOG8B4uJKVsWaojSYhg","i_price":82.56,"i_data":"LKHJT3bkqBJxu5JBUidscUbmuSP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":88,"i_im_id":4933,"i_name":"G1IOV9K2NNS3xo9pGhUwyGy","i_price":53.15,"i_data":"56JEhMt2s2A7rWqFmsFQCVIRcMeLPvJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":89,"i_im_id":7845,"i_name":"gMBEZ5rY0IxiDn","i_price":33.2,"i_data":"vfXYRQCEANu3mmP0J6W3Ask74MI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":90,"i_im_id":3914,"i_name":"LKKyv5Iyyoi7rz2x","i_price":5.71,"i_data":"t9bUiwlGLCeKDbaoH3RhU7RzDKN8zUC6m2Tc2sBRQld7BUlH5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":91,"i_im_id":5818,"i_name":"ou1KaxGwHXKeqEnEIHu07JYo","i_price":45.35,"i_data":"1weXP2jeLqxjczPGFWRs58xB4tolyDgz4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":92,"i_im_id":3045,"i_name":"f4uNzlSUBx2oac0oXtFj","i_price":28.64,"i_data":"afSwGAQmzhbYFlpiPa6soN5eSxTL9sRB71cPQjIZb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":93,"i_im_id":7742,"i_name":"ydqWU0Zcxp52Cvl","i_price":43.42,"i_data":"fOFGtil4yTmszvxTwGetRvhLGT0GLpgrT2mE0FRdp5OyNa4sqT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":94,"i_im_id":9967,"i_name":"VwSTOQY3Nvwvwl7H","i_price":62.65,"i_data":"K4Bt5ktfdiif6fGag2XBTZGuoSb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":95,"i_im_id":2286,"i_name":"nQBItoA4Z6BRi9ryHZCJ","i_price":84.01,"i_data":"KWRXiuMlestmq8rjWf13JM2wsC43oHuie0M2Xzb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":96,"i_im_id":3886,"i_name":"1wNlTDhBxDy9pg1t","i_price":62.51,"i_data":"mXJuXFKYVtHY9Qb4SyCO41nnlzUW8uuTBVNZkQYQ2ZGMShwAx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":97,"i_im_id":9012,"i_name":"3kQmYMpABeL9Fla","i_price":61.47,"i_data":"KMqPXaT0A3L2LfixUrHW4g1sX0284BwZXj5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":98,"i_im_id":2628,"i_name":"rFmeR8mqXfQf6E","i_price":97.84,"i_data":"6pmsPw71CSkX761nFrUkaI6VvDAJEza5iNTb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":99,"i_im_id":2181,"i_name":"A1wk9yteGWCZQBr3C","i_price":22.65,"i_data":"S7t0dHkRF5dJDUQdaMeJp0rsDYDwB5fqmVSutep8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":100,"i_im_id":4526,"i_name":"VUdyA2qWjBla2mcgbphX3b","i_price":35.94,"i_data":"AcuF5s2EP104j3KyBvydVs4aJKFH9W9X4koNFwWA8y87xdQ1M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":101,"i_im_id":571,"i_name":"Ozz08niBb8usTCQ0Qne","i_price":84.45,"i_data":"uzeux4wvxRjXe7XbzncCPyKQkWm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":102,"i_im_id":125,"i_name":"ABrVvjo7Ez5J0B93Lrm","i_price":57.63,"i_data":"B02Zaxj8nvqq7ah6Ju6L9vGR6lhpx2UBy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":103,"i_im_id":1854,"i_name":"RfGAEq03TSNRARy","i_price":57.03,"i_data":"DDKjfB1ICs2jLKnZEAQQD0T7xJw8F7BTFX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":104,"i_im_id":6274,"i_name":"xQVPiCddOZqGJuFBB","i_price":30.13,"i_data":"Locba77jHqjvoriginalHm2Z3InT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":105,"i_im_id":7928,"i_name":"1etc5ANYFJyJmKAqQ9ZLc","i_price":47.76,"i_data":"NBIPCxzcJHyptqmqFmj55zmQdwqx3Lluh1w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":106,"i_im_id":3270,"i_name":"R7Fydl21yZkUNQe","i_price":65.71,"i_data":"ZkHj4PJwsMWW0Yx1ARtdaFXAon7Q7sjwviWBCiK77Boziqh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":107,"i_im_id":3201,"i_name":"49NmzJTnSOdfcer","i_price":91.65,"i_data":"uiDqO5HYv8mpWX1UkafHSZB3sZdKuz3B7H7vYvedSrQdMSZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":108,"i_im_id":1625,"i_name":"izjZOirYviwBIYCJf8TK9","i_price":80.61,"i_data":"3MRTcTDd127lP27yIyIQCmX7rRBD5Kl0tM4ouIvKTr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":109,"i_im_id":9635,"i_name":"8ZlJH5WwFTs9ZZIIjwVI","i_price":32.59,"i_data":"qIa8ydSeEgXffvmdEzeBZruZjCH1WAdrzhK6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":110,"i_im_id":549,"i_name":"Tvpf5XFf18BkI2T","i_price":86.11,"i_data":"cICIn42RfBGRvbMkFr7AG7R5S4Jgc48nhQQcz8pAkbsrY8vz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":111,"i_im_id":3757,"i_name":"EnNdeREPTldPRIt","i_price":21.64,"i_data":"LEuFrLURUADP4TwlV9YKffgIJ3QWBVw6fZlhJA73K8VxB53b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":112,"i_im_id":6497,"i_name":"QJje68AM5qxMkahvEy6","i_price":72.86,"i_data":"VetQ8plU6zBCVrgM5C9NOdCHEJUAJld25AN7xbJo4IROndh8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":113,"i_im_id":6352,"i_name":"afyrl7dgzuV480wawSrZjz","i_price":27.44,"i_data":"l8RhLNxwpGYv5nO0GWIUUc0MTNNDsbW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":114,"i_im_id":632,"i_name":"0ZYulphBWFzzVhbopWB5sRcO","i_price":72.51,"i_data":"sMUTSF843TYsUdR73Cfwf6W9F4sgGu3qhVLRVwzxeyT26ml2rz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":115,"i_im_id":6529,"i_name":"Zfyuiw5jrlT84oEtr","i_price":18.46,"i_data":"MHJqBSJzEF7Jl7PQrYAPH5mFAkwF34LPBUfVksunCfkNTMy3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":116,"i_im_id":6478,"i_name":"rglgIlDapRkVgx0GVIJL2vF","i_price":18.76,"i_data":"wmbh2aPQu2ZwmOh9iyk5yGX4OziQ6jE66mALw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":117,"i_im_id":1434,"i_name":"rvNzzk15hv27prn0IUt","i_price":37.15,"i_data":"PAXN7kx4hcsMWCtLihlXqPd5BZrsOwZ3o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":118,"i_im_id":5358,"i_name":"B5jsXCoZFMg11Z7Q3lfT4","i_price":80.94,"i_data":"Ne0FCCKhpyfFeNQgVUBYleAnOJJwWOQWZ1PfAZjkHr6s5GBIg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":119,"i_im_id":7452,"i_name":"XtcVi02GCdnEZwIh","i_price":92.34,"i_data":"bgpBymkWu41VwvqiBdLWWFdWD7MTtLXMHuffbU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":120,"i_im_id":217,"i_name":"VRzokuxwKlMt13","i_price":90.36,"i_data":"hHJVRTIqtSTORSk7J3lw0nQJTlJ6TiSiQHHSl8YjPDb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":121,"i_im_id":3407,"i_name":"q8rdaB59K6MKmtqNW","i_price":25.54,"i_data":"TLYvkYgHLrTQW3k9iGZeWHNcpq7i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":122,"i_im_id":1407,"i_name":"UIQISPb9lFt40jwszS1eCNMA","i_price":38.44,"i_data":"aLC2rkDs3qB4lSOtKQsqMVFPN3wPpm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":123,"i_im_id":8174,"i_name":"jLNs6gczzjWS24XDgqZxy","i_price":2.77,"i_data":"iGppCdforiginalIqqlqzk1Qa5lSaCsW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":124,"i_im_id":6718,"i_name":"9MyEcJV9oYGtqpoeizPOfD5","i_price":54.35,"i_data":"YNxX19EwrkWTpjQVqmij7zvwnMwCMRkS0KvYxhGKB3kBpyiJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":125,"i_im_id":8185,"i_name":"QYRfBFTwI6cynn5","i_price":90.97,"i_data":"hoEsQRv3U86IPHmHWhhWbhu2JeM7zi1ZPVTwjg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":126,"i_im_id":7039,"i_name":"jrqvSepuV66EWGE","i_price":56.22,"i_data":"qVfKK2HqXLl1RwE1QPvN8YbpkwyZpNzfTBu2n6xdLRdCvb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":127,"i_im_id":5141,"i_name":"9Mlr4wWav0CuaUHxX0dT8S5","i_price":27.14,"i_data":"zb8BQt5VP62CPaE5YdsHsRPOuLvJKP3MmcUCGrcDsMmV2MI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":128,"i_im_id":8773,"i_name":"c68sxu623O8YDChZb","i_price":28.31,"i_data":"3originalhUj8Gf3DWMH6XpRwAp7IIWS33jzRN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":129,"i_im_id":4613,"i_name":"cHGbyopcwn1sOJ3C1JaI","i_price":32.28,"i_data":"7y40aARw6ZAcS9UAr4v3CaPpIhn4O9vZWnYojMIML"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":130,"i_im_id":4833,"i_name":"JTQM1kgzYQjbEswu4zrcDcH","i_price":74.93,"i_data":"Y0ASTRjV2GglptzwjQ4m4tRmdOtEg5JISh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":131,"i_im_id":1813,"i_name":"wsSCg4pxP4GnKIQQKR","i_price":38.4,"i_data":"xiVcis0ne35jPquW6eV1Th9d8sqG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":132,"i_im_id":105,"i_name":"5JIxvfplUTutABiR6iqquxT3","i_price":94.42,"i_data":"UFjykLaQwbPSFRAaR8uAoWab3u7yjk04N6TUvsXHQzh4StmXb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":133,"i_im_id":7672,"i_name":"bbQcAYd5yUpIvoV4dWzI2fR","i_price":52.26,"i_data":"woriginal8WeJFPAgeo8g2B18vZY8Nk4uO2I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":134,"i_im_id":467,"i_name":"OqwlZpg0tmTThxZUFz2DmgN","i_price":22.97,"i_data":"dINOFq7uGbwoffOqmeL50hha4YLq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":135,"i_im_id":3409,"i_name":"gFG1jBh5jgQNqDEdFVR","i_price":90.09,"i_data":"FgToriginalmFhXdn0gTcLDNbo43L9wZ1wAA4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739181,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":136,"i_im_id":2912,"i_name":"UHJlvkLI7Bu8Ar6wnY9","i_price":68.67,"i_data":"JSArLVg1y0273COVErduAhzyKQGDuK5FHrnqCPKGr6auSm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":137,"i_im_id":4690,"i_name":"dmajuncDjFIHNFrsZ","i_price":86.62,"i_data":"aDQC8d1gIXGlHLgGUcfIKoAtGZ3Cuo3yKx9K9NFk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":138,"i_im_id":9259,"i_name":"gvSYL2kDTjx5150V1D5B2I","i_price":21.24,"i_data":"aHpc00vW2rRo6w2h6kjTTnFM3Io0ZGpALfqYajr5OVKGqSdoR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":139,"i_im_id":7036,"i_name":"nAwyOtDhkko4E7I","i_price":44.28,"i_data":"udX0uvmuGswyYowBI7iDfRgpClyCvGxwhyql5Xqykx17yjsDGT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":140,"i_im_id":8763,"i_name":"tuNba31NCOwxD2UoJiXAOB","i_price":13.75,"i_data":"3YcIowjoriginalG9yUGibCsjPwjN9TwEgmn1metpHmZtk1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":141,"i_im_id":5735,"i_name":"xIx1Qj1OVMQcbT1","i_price":42.71,"i_data":"0DRZrTHfYhpzxTIRDNsiFXbiDowQGwd8lbl7XKA04G4Hx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":142,"i_im_id":7141,"i_name":"nXUNnjAQqfCH7YbOYEF","i_price":18.33,"i_data":"b4YbXt073tVGKy4xaor6svc1xWQYQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":143,"i_im_id":656,"i_name":"GyVEetmIcJ6fP2kHGEq","i_price":41.56,"i_data":"3YMOqXzljFjfy0YQ89WCloUMIlzxSZ8Xr7YJKgTTc2gOUb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":144,"i_im_id":3280,"i_name":"eTZtcP4XTBAGXP","i_price":14.12,"i_data":"arCcrGjo3p9rhrzN2wluyFs4VeCbiI8qR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":145,"i_im_id":2371,"i_name":"kxUO0WQNUzieeFTryflebY","i_price":84.79,"i_data":"DtgGrozrny3BbpmrVQxqjPFPoTya0zMxam2I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":146,"i_im_id":962,"i_name":"qomB8fW6cCL67QXogBSk","i_price":88.05,"i_data":"zlIzhwMeELzkZz0yp62LKXe3RYhKIYSNnn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":147,"i_im_id":7181,"i_name":"I6PVW0ObtbHri67iGmMh","i_price":46.71,"i_data":"DYPPhy2Marw7AeHcoCSH0tUHgE4Bx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":148,"i_im_id":3703,"i_name":"8Sx0gcbAFZ48vnXANPoQ7","i_price":74.8,"i_data":"OcFBcc8alhJWhtoiFbY1oc48yUDFjDCSjn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":149,"i_im_id":5450,"i_name":"F8sItBZdDWaV7jeghje","i_price":68.12,"i_data":"t0TND8O9KQByb9ST9IPfToriginalYpBg5U"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":150,"i_im_id":2086,"i_name":"6gSSrGFDR4aB98DjB","i_price":60.05,"i_data":"7f92wmDXfJQZD8iu1wIDNkW96FcWhyd2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":151,"i_im_id":4538,"i_name":"TUClmpnVo3kzSYFFLY86HIc","i_price":39.9,"i_data":"paVNyPhW0original714cNs4cQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":152,"i_im_id":9517,"i_name":"3YUGkPko4spNRqs5vU7o5","i_price":61.46,"i_data":"yxpbDXnpgUPw9JbMRUyC7KGOoTM9HyVDSxpNrVEIr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":153,"i_im_id":2327,"i_name":"Qq3pEfIwdn3VriDZtybfx","i_price":44.47,"i_data":"XWFwA3YoyOY0kxOjBG0Yk3NlWQ2bMjX4pT0Rz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":154,"i_im_id":2681,"i_name":"f1mklqyXiMP7dOqMXJxWOwK6","i_price":50.68,"i_data":"YOMxf2J96wvWyqunrNyApK5EOPclJp2QKQrUTZhnja7UFig"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":155,"i_im_id":9062,"i_name":"JpiKYYF7LnAgirAbRwzcI","i_price":9.11,"i_data":"CiX99BRMQhuda5L80ZnlD1hOOTo5UEUDOb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":156,"i_im_id":4220,"i_name":"YAIMMo7Lvqjkgp1","i_price":77.92,"i_data":"uO9wZ25D9dFgv4z7OZ712Vby8xnFNblMuYbkBsRS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739182,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":157,"i_im_id":3781,"i_name":"0jPzybyTKB4l5W","i_price":58.44,"i_data":"jPHwS5hPLbvn1qxZRpbDzeeSah9HGOPNSyUzC9vVmIjt7oSgs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739182,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":158,"i_im_id":6747,"i_name":"95xkmPy8aan6FGGfFhcsYj1B","i_price":4.31,"i_data":"PDHkdgRYWpLUInjcJa49YEpE4kVwRVssb6yLp5ZVH0xO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":159,"i_im_id":3390,"i_name":"vGYHhVcP44YMXvl","i_price":28.51,"i_data":"1pPGlbLP4onGJQAdFz5Z89PyhTbZini3p7oQE5mZwsEcKWrM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":160,"i_im_id":514,"i_name":"0egbqpQyvZL63n","i_price":6.44,"i_data":"8Nzf0JvLM1ekNbDDgJ1AklcZARwOlAglNiBT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":161,"i_im_id":4565,"i_name":"X3PcRo3W4Gcj3YxMV","i_price":40.31,"i_data":"JkoriginalVGyomKKdTxbbeOzrf9cMCMExrREz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":162,"i_im_id":3803,"i_name":"ST8CO1SdQaNA76lTZKeM","i_price":27.02,"i_data":"JpsPtDMhcH6TXQjEJz9yaVTO5mC7fg9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":163,"i_im_id":9905,"i_name":"DCiyeiMTAKkeKdLWxk","i_price":75.53,"i_data":"gHAKeeYmYxIvCGA68wjWqcT7XFcu6dedQoGLimdB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":164,"i_im_id":4417,"i_name":"ZBwv0nClcq6fF0sdiMcj","i_price":42.58,"i_data":"fKO2ya5s511J9frUYJrfBGDa3E212b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":165,"i_im_id":7025,"i_name":"VC1G6LgLCKJLHjJ","i_price":31.32,"i_data":"u5rc7WHbTJGXuoriginalr25Kb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":166,"i_im_id":3219,"i_name":"CUUpEQEwbFdyJLPEIjE","i_price":69.44,"i_data":"PVwURFtt2Hj6EtGU9tG3X7Z3rVowBSv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":167,"i_im_id":8029,"i_name":"aNodcnMUwPoH4OoUN6","i_price":8.35,"i_data":"eupx1ADTbO4eYoJhzT7XN48aDci5vBCkHtdoDBJ8XjCUM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":168,"i_im_id":8649,"i_name":"I3Zkc7TaoqGFLynMr","i_price":76.1,"i_data":"X0ArKgnlrs8aKJB0ebPSpnriHAffjOmfP4wlRs1CV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":169,"i_im_id":5075,"i_name":"4PXGohN3FzrI85","i_price":3.25,"i_data":"vd7WFgXs4aA8JliKBrP94VFqC7AtPdphWffHdb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":170,"i_im_id":3540,"i_name":"JBVsyj1w07B2GH","i_price":76.01,"i_data":"hVQbabaxIp0IDdEMu303hqYOSRWjBkBRNNBFNCxBAzEq4w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":171,"i_im_id":5622,"i_name":"HpLOzAkdn8FOHzT","i_price":22.04,"i_data":"amSB7ZVWJZFL5dbIoPs7z21JdY0QCEKZNh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":172,"i_im_id":1394,"i_name":"kTvKE9YjTLE2fqq","i_price":34.95,"i_data":"rOJSGLiK4yrwg4hF5G8zvAZ9t0eKwD53u95x35xEAv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":173,"i_im_id":3200,"i_name":"JKb2RyFGjidyp9teM","i_price":32.21,"i_data":"rfBPIE3aD3bQjrERgdOWNJfbMHForiginalp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":174,"i_im_id":7230,"i_name":"DGbeDwQDRUGKdSCrERPep","i_price":55.19,"i_data":"dwnvzHXaTeY6SbeOMstrXYMzJYlvvQwDVzMdYyZgb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":175,"i_im_id":5941,"i_name":"hWbG9bE0Wp48BE08P7hb","i_price":54.19,"i_data":"m7SiuNeI67lShsRr5S9Mw7hOZ6tc6pFtRhVlnkptJk2mmXOQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":176,"i_im_id":8960,"i_name":"5fxjgD4VobVCFVyvWKw3flox","i_price":62.2,"i_data":"uvKKH404KZqmn8bSiZaN0MUi8BqI2x9g1pt39HtQl0cDP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":177,"i_im_id":8529,"i_name":"R25vnJLr0nsNGPt","i_price":52.03,"i_data":"ZMSzlPaYM13uXlzH2NzTuU08D7HtxDoriginalj90"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":178,"i_im_id":6302,"i_name":"s4XVPloxW2sntECc3wEAPNA","i_price":72.57,"i_data":"dMU942sYb9tmFcJ6iBBaJGWdNoHgAjLic51dZOuqFZ5Px3db"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":179,"i_im_id":9402,"i_name":"pmivv2mZoqInf5HYg","i_price":82.4,"i_data":"uoriginalcuvYKTYtikULZo2ochg64l35mGzBWQNCQDCe06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":180,"i_im_id":1271,"i_name":"uKGv1g5Spj7JMfySDgm","i_price":49.26,"i_data":"FcaWvc88GiXEQjzpz5mbvm7AnZ0fXVylovHbw0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":181,"i_im_id":4021,"i_name":"JR29ivcK2xxlq8C","i_price":82.19,"i_data":"2QoriginalLiwXmgLX25QU0Ow0Lg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":182,"i_im_id":1877,"i_name":"OsST9j61DJ3vNlX3U","i_price":70.54,"i_data":"JlSSkVBE0BS6H5ZKtqLZUAaX8dvIPoBu5H6vUaSYvZX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":183,"i_im_id":3348,"i_name":"NLChPAeLao3euOX","i_price":23.51,"i_data":"9mnj8OlNJRmwWAEfc2AunvrYJtIbyg4fvy1nmLYAmSrl4Ab"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739183,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":184,"i_im_id":6070,"i_name":"8Wo8hsuoth4MVjq6JT1bopKV","i_price":92.28,"i_data":"eAJXDBykbQtdn6UgYBVq1KZu61zMxSuBW6ZbHtwtgAyMAUob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739183,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":185,"i_im_id":4011,"i_name":"ajqkL1CxrCwaYpU","i_price":61.41,"i_data":"Bw53ON0GCc0QWqXqO6GaAbMYHhdWP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":186,"i_im_id":4400,"i_name":"PVfFRi1A7ODcSgYSyp5cfx","i_price":61.75,"i_data":"prDdH3yhZCPnaP8US5J8eCvDtn3Fw9873bZsQrZLNs6vI0ugz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":187,"i_im_id":1612,"i_name":"Pmxcw6cnA4nDap","i_price":35.73,"i_data":"LPfOZB7ZinL3D7aMBfGQr036qS2wtV19"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":188,"i_im_id":9617,"i_name":"lJfAJ8RJ1sxsbmQS2Ck","i_price":17.72,"i_data":"cPOPDV4NgoP0fxelfuz8nqdUtGt3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":189,"i_im_id":2530,"i_name":"bDNRIv4PwbWiLcePGkt3J5i9","i_price":86.21,"i_data":"Xi5OyySbfIYctLx8T7B5IFUSLB8on3E2pkidCdq5YN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":190,"i_im_id":1157,"i_name":"W7PGy7dUw7CdNksU7Y6ITI6","i_price":27.58,"i_data":"k6F8XzJZfJiQorpSbrPCBSyKGxlvl99FjlF42U8v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":191,"i_im_id":4114,"i_name":"k2Rf2ysnXcfq0hTUp1e","i_price":83.2,"i_data":"U04N3NpdDIdKuyowqINrIrv5LJHCRImk2j98KkreHxkJOtLCG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":192,"i_im_id":3737,"i_name":"Zld8Q5yRf6eiE2UNtz9QK","i_price":56.79,"i_data":"E7NX3IC9QbsNceZsIfmAb4tZKxKXMEJPALAwDgkYB6A9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":193,"i_im_id":3638,"i_name":"Y0rUgo7FlunHOrgdwYEYC","i_price":27.5,"i_data":"MzDM9hdQnmvFhjCHNtBcdCc6NyWv8S0gSANcmFbfd4016zGOw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":194,"i_im_id":8857,"i_name":"NjPiPAfJzD6iQMN","i_price":5.17,"i_data":"Ve2l9EY07lUB7KE2bcC87dFbkRyjPvxm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":195,"i_im_id":2755,"i_name":"z3cSvDFe3sMKsHyfWCRZdXQ","i_price":71.94,"i_data":"CoriginalOQrI6mio7RGEk82jz6mJxdAAEW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":196,"i_im_id":4901,"i_name":"zyBFm2DG74zK26LL6Ga","i_price":59.42,"i_data":"CNKNTkPmndL8UZ6BhdQ1uLdrhVQUet15Xqe4rb2Bcrkb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":197,"i_im_id":822,"i_name":"0inz3j2V9HITtly","i_price":87.03,"i_data":"FGPuZgUT6KntWvpTpLx2XK1MFGsM6FbIJPMAy5pjV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":198,"i_im_id":2904,"i_name":"QlrPeUnoW8XLUUoGc3L","i_price":95.45,"i_data":"zwA2OTWJpWAZv2XuRxvR8oMPreBGPQDi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":199,"i_im_id":8988,"i_name":"YddOe7TTfksgIwowK","i_price":34.06,"i_data":"jMYAoriginalgbiXX6dGTDus66lschB8oJb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":200,"i_im_id":7050,"i_name":"v31Ksj4S3H5erUN","i_price":54.72,"i_data":"VRURtUoOD8jSyap6hVYFxWXahmZN6IPDTF9wfgkfIhEbAPaeQH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":201,"i_im_id":9129,"i_name":"MpeUE0Nuims5wo","i_price":41.58,"i_data":"KbMYxgFgFXQUahn09PzCD6a073Tjb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":202,"i_im_id":9793,"i_name":"UpWOpD31ZRm9hL6W","i_price":64.43,"i_data":"lvXFGoriginalwR89GG1a9RZmn6BOujtaHVoBJm0h48YKI6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":203,"i_im_id":8467,"i_name":"IRQlEhhRvhsUUiG3t0O","i_price":40.17,"i_data":"8EhzBxNbk16xOVFwpj7JuXpFQxyVfWKPC0D9X6bd02D0V3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":204,"i_im_id":9885,"i_name":"qaP66yKXl8iuXduawPFxe","i_price":38.91,"i_data":"bg60QyJQTpmxFrxy6dRAAnzFLLoqdyY49wXCvt1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":205,"i_im_id":6432,"i_name":"FOPiT4q7ipPm7q","i_price":68.26,"i_data":"aotdc5aOgw49ozkV2QUE75G5rw7bQyo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":206,"i_im_id":3793,"i_name":"weIpCGsT1Vl0eWE","i_price":40.43,"i_data":"zArxYTmE0rtljA9K46originalTYPJcFaxBzh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739184,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739184,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":207,"i_im_id":3389,"i_name":"mngVTPQkazW4N0sjj","i_price":1.81,"i_data":"vGHQXXYTyi2pjE4sQfEc1gYGs4bHc7oENNNu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":208,"i_im_id":5984,"i_name":"yGIKSz03msfYEVQI2qKIsj","i_price":50.91,"i_data":"kHY9LuLnvoRGHxTbDbq539XDE4qV2z9vwb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":209,"i_im_id":8479,"i_name":"1gJrHpBOwxH7oDo1JSqPy","i_price":56.75,"i_data":"eJlzXC2gAFyN0BXc3WPqlV7XqbA6cY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":210,"i_im_id":7718,"i_name":"OottD147HMIqmg","i_price":61.72,"i_data":"WfmBBpk6ie7XTBUidU7s9axM330MtwJPFsRvEEZdZo0zIVCG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":211,"i_im_id":1320,"i_name":"JPOuL9XM8O3QTKXVeux96s","i_price":8.57,"i_data":"ODZHTTuQe4i4D9x7v3eExbwhZvn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":212,"i_im_id":2369,"i_name":"AztNBsoJYVC2n3r88zLmm5m","i_price":43.48,"i_data":"hmwilRESKzoriginalq9YdgrISiDwgcXQV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":213,"i_im_id":6041,"i_name":"JpGTI43TmzE0mMxy","i_price":42.56,"i_data":"JMNfflBu2mDfMYJKz3Mc359fUDSjQ31"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":214,"i_im_id":8024,"i_name":"P2CnLZ6wjMWagfa86PQ","i_price":9.75,"i_data":"SDk7yGrLUDzyFfYaYAi8TBAVkZGTmlhQyIp8STMW3IXH5YJ6Y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":215,"i_im_id":2364,"i_name":"GG9JFc5ppg31GCk5pThel5qT","i_price":78.39,"i_data":"PPlHEqHtOIdWE6wBvPoE1nLDg3MFDtaDvz987cgptPl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":216,"i_im_id":7385,"i_name":"566cawOsOsW4jKu","i_price":64.62,"i_data":"jTj26bjhOcBBKF3llggqx3RrWEfY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":217,"i_im_id":3982,"i_name":"lMahW3jFsjEElYo13nxgfI","i_price":1.21,"i_data":"G6lH247rpdd6vi36NX9RZCpGTBSfIs4DYjfJtZjeSBQJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":218,"i_im_id":123,"i_name":"Ha1F2qejGQlTDtgyHxMA3","i_price":95.87,"i_data":"f2LU8XbUP44abHu6EbYRSSkD1EOyGsswb3RHOb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":219,"i_im_id":9611,"i_name":"FnRIWPBtJtx2CVGH2cC","i_price":38.62,"i_data":"ETLSmXQ0JTEqO5lUkstTFPjvvhw2VajM94CgBfGzT7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":220,"i_im_id":2037,"i_name":"ywbfIhFx8pBVpRXty","i_price":29.87,"i_data":"vHhjbtmGfPRfeKwvfejzeSHXW7Li5J1GRXO3hluFfVDAi6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":221,"i_im_id":5610,"i_name":"lk0ed5qKtxeiC5144l","i_price":95.73,"i_data":"rWwEJAGD7ARRhCcQB1ZKKMoriginal"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":222,"i_im_id":3023,"i_name":"7iGc7POUuDtG3DXogP3Dx","i_price":32.61,"i_data":"CshPW04LbnndQqaUDK3gcJtUFfjMtrMkP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":223,"i_im_id":7180,"i_name":"bmm0lD9EwbCu79JiYcOI4kD","i_price":44.79,"i_data":"apdldGHoriginal7qyhL3aA0u9duxRNUrGk8EwrK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":224,"i_im_id":141,"i_name":"9ma1cYNnsSjd010d8n","i_price":67.13,"i_data":"nwSJ3M7hlXAskGFzA9BldpnVBxKX5bVGyAvxdqWo7R8m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":225,"i_im_id":5710,"i_name":"QyIkFBfP0PBEILVA2G7w3","i_price":15.3,"i_data":"PcE6tldHrG30wLLn63oaAyZb6CuwX15tb9GsuH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":226,"i_im_id":1046,"i_name":"TeQjJV9teIv3JtDnPw","i_price":75.99,"i_data":"6KDwPgK7ipcjcrIWcgUAaThU4KjWQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":227,"i_im_id":2503,"i_name":"LD1d9zdYvNiWvXI2J","i_price":86.98,"i_data":"f312cAY6cpxgTHpzBUdhV1GksW2XYJVIxZe1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":228,"i_im_id":9123,"i_name":"4MNJeZprl08AIGHAJO7HAm","i_price":42.25,"i_data":"EglasvGcEv6fnjQTcUGoboriginalg3WmCM9zX0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":229,"i_im_id":9043,"i_name":"8N6cAtUlBbvAW0Iz1LgkuN","i_price":29.56,"i_data":"zmSPojWJajF2ewjKFfF5T8UCN2s6CJHhgc9QPFj8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":230,"i_im_id":7857,"i_name":"0RBB9b7MYaFSSY3DODqP7","i_price":4.27,"i_data":"cy5oxFmYZ1KrjlXXKOFtLP6gcpbtqgcnqxhEqN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":231,"i_im_id":4498,"i_name":"CCdirLrXki1nXilEYs0","i_price":21.2,"i_data":"Q7W5ujy0gZd8XQQknp1BK5N3dKFUuy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":232,"i_im_id":7719,"i_name":"moZcAiO3KAuJ87l","i_price":40.04,"i_data":"0iWjRjt58Obq2FMvpMwQPj3QChVamk1Oqv3b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":233,"i_im_id":5840,"i_name":"Lsdjj30h9qW8xr0h2","i_price":68.2,"i_data":"eb5KSoriginalZBCppBmPqAwvbiZ6jwS1W6gJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":234,"i_im_id":7672,"i_name":"CYJgePy5xZp2aclCtxsNKwr","i_price":61.92,"i_data":"bRN38DelaY8eMncqBZSFvmmAUwHRrI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":235,"i_im_id":1510,"i_name":"gqUG8XAT4pfEUXP","i_price":97.45,"i_data":"tfBvB9PTWtNNXkT9zFplQaURye4FqkoOZ3b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":236,"i_im_id":4860,"i_name":"RDTFeq5N4KriyXs0kmtlYh","i_price":1.63,"i_data":"3VOLAAbNCHksiqoirKw2QSEgySJJdovAj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739185,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":237,"i_im_id":4717,"i_name":"r0FWekbHIqzVzaJl1EIGWGsF","i_price":7.73,"i_data":"z6yuPOUUeQ9ApONGuwc6jsC77CbSM33JMjSrg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739185,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":238,"i_im_id":4341,"i_name":"i9dJeWHcp5H51O6yR8","i_price":45.27,"i_data":"yxHpQJc5CfkVMV5DUZVkl3KAT1GRgRqYVkqGLgxOnX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":239,"i_im_id":3789,"i_name":"m9DtL2Ki8CdBeN","i_price":51.53,"i_data":"LpQjdYWs3aMye1pes8y2P0x4lwD9xw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":240,"i_im_id":9225,"i_name":"IQasbB93zcZUfc9E208zyn","i_price":58.78,"i_data":"t5jjXZkvEoYjqX5wY8AEMYbsyJZ2Iqk5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":241,"i_im_id":5829,"i_name":"BJLAO7KAYYdCgayAR","i_price":7.82,"i_data":"GbaxMTMGh5Wq6GBPurIk4Rh4bqEujEom1SUaO7Lt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":242,"i_im_id":8195,"i_name":"jY8NWI3j4hRW45","i_price":88.93,"i_data":"IxTrhAiYgwYDn5yrQsvB75uSHxXcebvmb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":243,"i_im_id":240,"i_name":"eqhYTsngwylVxKCCfTO4IKHX","i_price":72.61,"i_data":"gqfeum0QkCnUsPMiRZuDaseHBhOAlZUuB8GUKIqH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":244,"i_im_id":9621,"i_name":"pYlDV1rHMwOZ0j9TTMKNUeY","i_price":96.96,"i_data":"WnOId1DejHv26wVwpRtiuN458kbRoMLn3Kkm94rIMK0MUI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":245,"i_im_id":4597,"i_name":"cNDs0qxsFtQmNQhSCaOAc","i_price":85.07,"i_data":"drHjIVBuPVxxgT20iA3QeQBhK1hxNiAvkiQL6kTDJb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":246,"i_im_id":6075,"i_name":"vyLJQ6WgvsD6XCqcpGW","i_price":11.65,"i_data":"OLSSNX8ctePn8dmHw7VcQzfgXZ9hA3PNTyu3EotVP8fm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":247,"i_im_id":2329,"i_name":"Lg3tN2xbGorr6lY","i_price":79.53,"i_data":"IdUtJUmfvLpxxj5vt167EfxM2lhomYt459YUFl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":248,"i_im_id":7876,"i_name":"4AZnQvvsDCupgTHYlgHJMi5J","i_price":36.76,"i_data":"Y9ac6AzXCk5Wjxj95IS4fGPQAO3mBl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":249,"i_im_id":8923,"i_name":"PbELYJY6EYll76","i_price":95.96,"i_data":"87T6OweH2cxL8v1mXuaMoSTt1FSeT4sept8a2Lb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":250,"i_im_id":2709,"i_name":"1z7hqLI60armfJR","i_price":12.66,"i_data":"HHp70F02IUSPqwCh2IQLPAuUA4Fbo4EwZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":251,"i_im_id":2128,"i_name":"XGch0a918Bi8gsb","i_price":89.26,"i_data":"DvSwG1blMcVwToriginalnGr69qY6nk9n8dBsjLHsCHt1B5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":252,"i_im_id":1482,"i_name":"8lwJQ2YhxZOJUP5HSh2TU","i_price":9.42,"i_data":"KDneM4dPKtYftFsmDELwE8ns3e1ytFy5H3y9vw5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":253,"i_im_id":1196,"i_name":"DBEY5elKomZVss08MmwTJtQ","i_price":29.58,"i_data":"lGGRsFnjrYqe7DWZOhfs7hZt3T2ZU2GFXLLG6TAK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":254,"i_im_id":7750,"i_name":"9wVIpEIFau7wWvhG1EyyC","i_price":69.74,"i_data":"b6YhrB7Bs6vF0ezdpuGMABr4AkXSL9xULNPTy8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":255,"i_im_id":5447,"i_name":"lLgZ2NC4JVp5P9sa1d","i_price":60.02,"i_data":"x1FpG2Tiwe7G81dvtIiNEwTudZ7RIBoigp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":256,"i_im_id":1487,"i_name":"1T07PxRuW822PlxyRONOm9","i_price":38.18,"i_data":"NtmDNfzC9TTB4WbxWvzhBZ2qLFNKxaWQb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":257,"i_im_id":7268,"i_name":"b7YSy12TSvJ4qmC8q","i_price":56.22,"i_data":"N2keabPEH18hEzdrzzrjTEv5eKwpH1i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":258,"i_im_id":2193,"i_name":"qd9PzUTlhjEsekV0NUo3GbCM","i_price":55.35,"i_data":"BINO3dAbbEED2yL6eKZ3DoJIogS4vCM2s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":259,"i_im_id":7808,"i_name":"DEp8fSabNYG6dUnBz9j","i_price":11.36,"i_data":"ddOV35ERv3oTWQ1RGeG9A8t7uTC8ezV04McUZJjEsfb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":260,"i_im_id":567,"i_name":"FM9kzHbLGAqX4BD","i_price":81.88,"i_data":"Koszvy8b93J0Mr4bh156a78HocOowyrnoxY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739186,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":261,"i_im_id":3931,"i_name":"zf2p9ajWtGH29kZYoWdGrU","i_price":9.26,"i_data":"j3s0v9GMCsMdMRlXZh6Vj6vEXwjkoY6FRI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":262,"i_im_id":3179,"i_name":"sF4gpiUnSfXXcS3","i_price":81.31,"i_data":"TIWlk32IKdL3mJVDWFWruOTtuBVc2XGkgT63jwZlNM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":263,"i_im_id":6479,"i_name":"t7esI9bupiR2eHMV4WLpc6J0","i_price":9.68,"i_data":"TQU5DGYO9oorjHQyss5ZaKiwocgwBu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":264,"i_im_id":9100,"i_name":"yuYQXEuOB5Xl2HnsqMiWlZxB","i_price":87.42,"i_data":"LJVwouO1SgpdHLKc2Wf9AvtBurKRqnngoriginalI4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":265,"i_im_id":754,"i_name":"PvNGMvjloNOzkY7R","i_price":95.02,"i_data":"EquXhkvporiginalITfJsnqbLQFth3WKTTTmiqa87bJbOeIv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":266,"i_im_id":5983,"i_name":"S8jTdmsSW6J1f24rSleyfw","i_price":18.29,"i_data":"HcaxV7NSdPuYLIGlgmJoKQq1BQNogDradF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":267,"i_im_id":4068,"i_name":"DPJwFp2rqttDmYfn","i_price":2.1,"i_data":"3FCZqC74RY3mFSpecR8luUp5PwqNw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":268,"i_im_id":4429,"i_name":"FBkn79ijeNnQlJ","i_price":70.11,"i_data":"FRTnKvOWmifY6oeNodVvygVUzoVGqfHPlwRbzmBd79CNs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":269,"i_im_id":4223,"i_name":"JMIryGgu5gPdQy","i_price":44.89,"i_data":"6aHdk24FvzW2Nu4HrApJSHumrAon31gelx574nBf0ZiOR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":270,"i_im_id":3711,"i_name":"SON0p1HBKsEKycIO1","i_price":62.97,"i_data":"403PfXj1Knt9OsViA4UMZH0iJr8tGIhciszPHC09dO66cTTMuZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":271,"i_im_id":7624,"i_name":"U7ErGpZpgas4Vf3SvDk07rf","i_price":35.26,"i_data":"WyANhUGhzzg4lV1Y4BUpJOjo8UqradhwHagX1dEM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":272,"i_im_id":4867,"i_name":"RwSCGJmUGMENAt","i_price":45.56,"i_data":"JWQkVBvYWmWGWAjexgxMdIvsBblwiwDXraToHGBhk4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":273,"i_im_id":3527,"i_name":"gey8CaKBqdhvVYLp","i_price":74.12,"i_data":"U49z754TIcFmaog53QvKkYUrE1pAum9r1pK02T8P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":274,"i_im_id":5930,"i_name":"lSg7tHj8Qnba502zVi","i_price":68.9,"i_data":"WasJwlvZR3N5UfUIORWY1KU3jjQ4QB6RjuYtpJ8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":275,"i_im_id":7776,"i_name":"NgroNYddwE8yLuWvvnCAbHe","i_price":62.72,"i_data":"yYASIWpVkXcHHtJBDyUl04JhJ6iVoriginalD08V9oGxVxklZ2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":276,"i_im_id":7455,"i_name":"tTMz0Ce0QrqET2WrpYjYO","i_price":83.68,"i_data":"A6ga7gnGfs6jxm4oyF7Rxdy83tyVeoqUb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":277,"i_im_id":1689,"i_name":"HKRnrsgsgCcnpX51Okx9b4Lr","i_price":67.91,"i_data":"soriginal6BbMtF1PkdlV6AhsQDIEEDVWqB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":278,"i_im_id":2555,"i_name":"rO69pVIhbbaAcs","i_price":94.95,"i_data":"jyLgfpBKbSvBFYISB7oN6oE1BWK3tpdAmaA1jsdWKqRki7K"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":279,"i_im_id":8266,"i_name":"3qEXIlYHLfzDPuCns","i_price":56.13,"i_data":"kguqVHkXgAqhetUUxfeSX6eG0b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":280,"i_im_id":3439,"i_name":"h8RjoESuZyGyDVXyK","i_price":14.13,"i_data":"46e0VOtka0ZHgYueoYg4gHoyjneGLbXSqSZdDmizZDKv7AsG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":281,"i_im_id":1471,"i_name":"CC9v9P1cgR8CMRIa","i_price":38.05,"i_data":"kag3PH7XiSfBUWTGQFnei4ZHZMXvEh7R8XCoizb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":282,"i_im_id":7636,"i_name":"5y2usGdjbBekjHaNR5Ln","i_price":30.79,"i_data":"vs58N9Jvb6qILJZEAOqsyBVtHX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":283,"i_im_id":5367,"i_name":"7VZxzGYTsR3UYuAax","i_price":68.95,"i_data":"ZAIRtgQdhgqBhQfN19EFo9Rn8aSbNUsJwvGznJkat"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739187,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":284,"i_im_id":3334,"i_name":"2TnUNcFERiiCNqn3F3ccxa","i_price":83.84,"i_data":"SATHDqUQlSYj2e2wjEjBAYcNUkp4CgQ2fW1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":285,"i_im_id":6898,"i_name":"eCZCT2xLDHkTlJ","i_price":36.75,"i_data":"fWMSm37u42lWGVC5fPGgRHkYrm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":286,"i_im_id":3006,"i_name":"PKKgsHRrVuEwXpXdE2k8","i_price":91.23,"i_data":"Th7CcbCWsVnGppWWCNIr2vgVzwjx1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":287,"i_im_id":1716,"i_name":"bHcWXuIKQHeZVYckcbXU","i_price":86.64,"i_data":"WkIeN321g3pX0X9qeam8ihG6lu84rjSSsCeUyi5oOb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":288,"i_im_id":7282,"i_name":"7dpSRUiiDs11nFzF","i_price":60.76,"i_data":"gn77ipA243B2KUy1VimKg1V95Nbz13wW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":289,"i_im_id":9211,"i_name":"lcU2uPCkdf1mWyawJg9mR8","i_price":21.7,"i_data":"9FtJfiRzFqtHoSzszRqNXU1HUrtqYrJt7T0LM8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":290,"i_im_id":9636,"i_name":"AoHcBTANC2iHwI8Q2JQe","i_price":74.05,"i_data":"wRI4E56OnpJtH99CFI8MEARAJKhetCVfHJrZYb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":291,"i_im_id":8342,"i_name":"536wlJlRD6XdEI","i_price":24.59,"i_data":"ASTAXQ2nNPzCRW2vfO9kv8F7iMSMqG96paLHMPWZoA5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":292,"i_im_id":9036,"i_name":"wTqYkZ3tbjLUfofA","i_price":80.25,"i_data":"OZfK1zLXMN0E3zkpZE314eEwPznTJKSzz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":293,"i_im_id":9401,"i_name":"4KTGz1GH2OLasUqOk","i_price":84.61,"i_data":"ygsnCp20rFI9LTAc4kK3ZUAg5eDkUvFqTav3ZNjCPkvzk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":294,"i_im_id":9124,"i_name":"57jRLEvhC70vpY9TT","i_price":2.03,"i_data":"eKREne1UZ19bQV92ae9ANnbY5zX4mab"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":295,"i_im_id":7497,"i_name":"va5tqd1huUVXAhstsQ","i_price":10.22,"i_data":"MJ3fBF4BOHh7sbFklTHo51DL2LV17odRIbnL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":296,"i_im_id":2203,"i_name":"IULk8S7Xao940y45iW","i_price":59.43,"i_data":"od50QlzSlazsebma7fwAPxZjhXpKRUqsW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":297,"i_im_id":4865,"i_name":"zXHVES5b2EC0vsIItf","i_price":17.83,"i_data":"NeCprVWIeqFlo9WxSxEqx0SQvSwF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":298,"i_im_id":3998,"i_name":"8eb2Pv2tbwp5ZBEXgDL9m","i_price":23.91,"i_data":"wxckWJdf6dYzfPsyOvGFqws1iuXW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":299,"i_im_id":6624,"i_name":"XN2bCEAUhcw5rNIG8LR6","i_price":45.78,"i_data":"IXHn9Kig97QMRvB7Mfq03updapRNpK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":300,"i_im_id":514,"i_name":"S67tRr7b6BImHJTYdbYGGUi","i_price":72.6,"i_data":"s6yeGur8dEY1X3psuZztsaPcSsujQIDEyu9K7mx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":301,"i_im_id":4034,"i_name":"ekmN97mJTm2eT1L","i_price":44.15,"i_data":"WfHWWCsWXXxLlfEzhLEzjNmAjoidVm3k6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":302,"i_im_id":4024,"i_name":"m3CoTJzGkqoWPOKnR","i_price":3.76,"i_data":"pKTwlX8Z4iUkZqD0ZNVZT9OnUDB61J9LRrTb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":303,"i_im_id":3970,"i_name":"aXDoaEFeEKvLQRrjUXxdJwkl","i_price":68.43,"i_data":"5hh39IbiIrBGGuxJrrTrRCptd8Wqp0NXX9LDeY1y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":304,"i_im_id":4674,"i_name":"35mvTwvJJ7zZStHT","i_price":6.5,"i_data":"dBhd1HTJL5TV1HCJSTkFBwpWsz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":305,"i_im_id":7425,"i_name":"300oDwvuSmWpAWJ5hbHk","i_price":73.41,"i_data":"NWY7hrUoUqm2moif0MNbAiL5RckI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":306,"i_im_id":4463,"i_name":"rdovPcFy50ch0vNKQ8hkJE","i_price":96.01,"i_data":"XeoYHIAd8Md7OnlIu236zd0S5zamMWTFCr7Op"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":307,"i_im_id":5207,"i_name":"OoKtbEWbxXW6ao","i_price":77.21,"i_data":"vPaq7ieoANMhZMAWNEGNBBUaIjnc9PYuHPBo1ZHWwAiH7YnC7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":308,"i_im_id":5707,"i_name":"6AaE9FzSJ4aDIP","i_price":91.77,"i_data":"BQvu82V61yYs0xJGwMqYRQ0QlnJPvolEGJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":309,"i_im_id":9789,"i_name":"AvoRviqVfUwbndMiqp0nrXDV","i_price":40.26,"i_data":"Pq5jRLh60g2MUvPhaQpDGdPSsw7Dqbn7YO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":310,"i_im_id":9745,"i_name":"2VSBF0bCzxNhDGL","i_price":75.25,"i_data":"3kWwbhJOrdhP8lGRGPJpTzp3I5bZ9puS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":311,"i_im_id":5123,"i_name":"2V1RlsmHYia0hT","i_price":22.79,"i_data":"mkRE8PVdFQHCkh4fZ2eDYZy4rBX063CJLaaPR7vn4iUKivm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739188,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":312,"i_im_id":8392,"i_name":"ReFnzIkgdrmsLw","i_price":82.35,"i_data":"tuUaBOu2Iu24JtCAhpdwVBJlj81bQmKqHMrU9QZmhu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":313,"i_im_id":7778,"i_name":"7GGctlwyuIIOtF6rknjJipd","i_price":98.4,"i_data":"KDThY5TsrpVffKn85TB0os3WlgMIi8J"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":314,"i_im_id":1379,"i_name":"BjMgnMf4ju3cNJCeJorx","i_price":40.96,"i_data":"D3iWD5cMRi7N7CNA1VoD4BtKLk8w7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":315,"i_im_id":8481,"i_name":"vPQugjl2n6DAumhKfg","i_price":51.16,"i_data":"2nfGn1NZB5tX2u1zr609SIXGAtIUozCYkYOJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":316,"i_im_id":5320,"i_name":"h8UPMYMGWcN5P1z1eaYRl","i_price":37.48,"i_data":"dzyhNh9kEiMiYko15dXkpn0WUoRJHIxix7ykb9dKKKUrKX8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":317,"i_im_id":5388,"i_name":"IIoOYMUof9FtQM52nruWrxC","i_price":45.5,"i_data":"if8Hi4s7xKVIxInf71Y688w8d36JE1uRNMRD5WvjV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":318,"i_im_id":8528,"i_name":"U9FiQLmkZAiXMKkxqKAJ","i_price":18.81,"i_data":"iHHSMeWy02EuFZyiHAzvTGXMCgxeMbLNRURNsxrbQo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":319,"i_im_id":3277,"i_name":"0embTdtNyiEuE1JYT4AI","i_price":63.15,"i_data":"5GmJ7O4zIpPGQ9WZs0nykxNP3GV7QlMEag09i0nlHr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":320,"i_im_id":1445,"i_name":"wbC52JhiIbOCRaVYsEEhBsjC","i_price":92.09,"i_data":"b0xrwJFY2QkfpW2arrA1mAzqy4iqb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":321,"i_im_id":2245,"i_name":"sF3z0wWUD0IC1pH","i_price":59.97,"i_data":"30NSjzKmTlQyVIpn4NmF1fBmqO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":322,"i_im_id":8825,"i_name":"4boPmV9IzZ27nNV","i_price":9.36,"i_data":"rhnSlH4HOMVjAKn9nbgR08SMkE1tg5eTB0FgQdeXrnpG29v4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":323,"i_im_id":3149,"i_name":"puu3QlA4QIaWKE3KrljJpwA","i_price":72.05,"i_data":"xoUXWYOhX45eK10YiwWVSiCZYEfl8k02WjW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":324,"i_im_id":5391,"i_name":"vpchajIrSdh1S1","i_price":85.92,"i_data":"fA959TgqpejM5VJOnwjti96FWIdBvWy4kG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":325,"i_im_id":2607,"i_name":"2DVIShlnyj6QdJE8tSC","i_price":33.96,"i_data":"c9orhAkZOvCunUEnn36AYrOhsHgq6v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":326,"i_im_id":463,"i_name":"7wjWYq8oGBxwYI","i_price":67.6,"i_data":"fJm4KOEbDgwjKEgbKV4LYKZEoriginal0akItw10"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":327,"i_im_id":6374,"i_name":"dkVmWP2ZbXcQJCWbV6","i_price":23.65,"i_data":"wbpwq2K6yXBpdvJZagfBwZk0uSmkNAWDHzR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":328,"i_im_id":7265,"i_name":"0SD3M25OEUzX5KXIzyV","i_price":75.5,"i_data":"J1k3qUjrszYX5HKpSNIjX3a6TVrt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":329,"i_im_id":3749,"i_name":"3cQ1MsSTnSmjnfzHZo6IWE","i_price":40.28,"i_data":"9xwne1xBwEUgwD1original5U2malJmlPTMDqzChdj0GUxzPY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":330,"i_im_id":205,"i_name":"NvdU0t4nciQvavt8haKWV","i_price":55.61,"i_data":"y1KbDBC9iTESqD8iExFlB2fvtsfZst3qHQnOB5riIjGgKsFZJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":331,"i_im_id":3571,"i_name":"ESwJbwgKXkb2te","i_price":89.19,"i_data":"0l7B2LnaSpFNQjydbEj2f6KwEYfHezMxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":332,"i_im_id":5321,"i_name":"jGClFsDo52NZvwRJj3RE6P","i_price":25.38,"i_data":"p5Y98RJ7WV84jH9h0ZO9OXuCmtb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":333,"i_im_id":6774,"i_name":"IP4IQvwynyjOcs3LytyLj1rg","i_price":63.21,"i_data":"u67mb55CHz0fCdS8IYiq4originalm5uFc2R7HZN7R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":334,"i_im_id":2938,"i_name":"fKqrXY2iItUCflY1","i_price":68.18,"i_data":"zNWGI6dd2NcYcSdqPpT0CjcJRZc0W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739189,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":335,"i_im_id":1388,"i_name":"v7MX26rwq1wfTfU","i_price":3.7,"i_data":"ynkYySyfOu9WoSdGnbKbv6GyTSovtsZfhv3sQZ3jG2UxyFxul"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":336,"i_im_id":7742,"i_name":"GEOh0768Ww2ngRsFgB26zxZf","i_price":11.98,"i_data":"l7BlEwyXNaeNQ5Nn7X23SfF4nVb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":337,"i_im_id":2533,"i_name":"xcjnBI7rtrPAT2nE","i_price":41.79,"i_data":"uEX3RomHTNftQ0droJhh6tYRrtKP9DFs9bRBTeu6SCeYl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":338,"i_im_id":2870,"i_name":"NOxDr6tBFvn6AzXOq8TBCz","i_price":18.63,"i_data":"47uNh57rjbcqhRGK0UcB3VYG3IbZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":339,"i_im_id":9761,"i_name":"KD5OlyNyl9nsO5h2zzk2eQX","i_price":71.43,"i_data":"AmaUW6shvUKKldnIAhnhuzOJKxVoriginal109YxjMGYQS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":340,"i_im_id":4236,"i_name":"EVvjOMXtGC0jwdFNybFQNx","i_price":1.91,"i_data":"cslAcEBdnBND5DFVOcyUseoyHWM4bFAo9rKjwBOHAN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":341,"i_im_id":2039,"i_name":"hk4mZI3SF2UubimAnMg3i","i_price":23.69,"i_data":"McnQ2p9wPv0FbmmBLCufqvSuy2Rj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":342,"i_im_id":9971,"i_name":"lW8ht52DgEgRKbhV","i_price":7.43,"i_data":"q1xHiphwTz9yaPSlSGvPGB9JfqRusF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":343,"i_im_id":9082,"i_name":"96pqRpUoKRYSwO","i_price":48.9,"i_data":"QY9YNpCYGGG0FImvWyB4zHTHXAfJUgrHxS8Tk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":344,"i_im_id":7605,"i_name":"n7aLzWfnUKnRqCE","i_price":48.76,"i_data":"5AHFi3vcKg3F5vr0sPuk2jn2AGWh4LDQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":345,"i_im_id":9058,"i_name":"1SrAieqkGPKYvaNZI03amiou","i_price":71.77,"i_data":"3IWMZQmrOQav1CvYRSaBLJE6f1JS0PolRJdhVI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":346,"i_im_id":7591,"i_name":"2HabGOdRtH4pxHO","i_price":13.46,"i_data":"nyBzXpZU6nTG5EIhtrqhjw32I7TLRoV0az0tQvvl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":347,"i_im_id":8914,"i_name":"eSWaeN354IZCXYLf4WW3XK","i_price":61.39,"i_data":"SlWiRSoCitv7IZJYcv4iNlts7Ykgb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":348,"i_im_id":6489,"i_name":"JUhj7Ch8XSEYCvHoDzZ","i_price":38.46,"i_data":"Fqi4rSoriginalLYfB3WxjXZqvi1hVaAijvJZdHljZ2mLoM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":349,"i_im_id":9132,"i_name":"QZpq09KFrQmOWTXOT72uXc3","i_price":51.68,"i_data":"xvnMsNPhxHV2xGXO1TzwbxLCoI9EEyd1oE6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":350,"i_im_id":5204,"i_name":"GNZ1hGReENDmqr","i_price":85.63,"i_data":"yH9RsQUpcV6ids0NzQ0AGegGhor7nyJzgKeF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":351,"i_im_id":8285,"i_name":"3Vc8cb5rWRunDjMRVuO","i_price":43.15,"i_data":"DDwiEVYbtGcZSpOyo03SHcOCFo39RkRv9xDmFgh9GPPZtW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":352,"i_im_id":8275,"i_name":"0j0eT9e3wJkll6xGB6PJ","i_price":50.06,"i_data":"Qnnfo74XodcAsU4HUVJNVRLjNEOBX7wEawci9CbH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":353,"i_im_id":3975,"i_name":"A8sSOqsEgmavpqduc8Xalg","i_price":73.48,"i_data":"5Osjr7JCJusfmKEvN7BEAR7E5RZ4Ip1oyLnfzoMk1P4iTDkb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":354,"i_im_id":9338,"i_name":"FR52rnusSALHmeMhRguAeb","i_price":37.18,"i_data":"87L7ZHL6KpOGCh7NxPdRrH89Etwm1mZnpIKKADxSFcmPbb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":355,"i_im_id":2769,"i_name":"lRx8wX2RW9W4if0xAWQ","i_price":88.32,"i_data":"58dxjqDgY0VuMFd3js1PpSR8IffMzH2FNXFVW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":356,"i_im_id":8412,"i_name":"7M6gx4o1mE14IrN0GOAitrdj","i_price":64.27,"i_data":"KT7jVhIII2EEO33RnRZwqnwZhCnpXa9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":357,"i_im_id":271,"i_name":"lNVGlfZMxDB19DZy3V","i_price":7.36,"i_data":"l3TTW1pnGnardYkvobNucUmS0j"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":358,"i_im_id":5438,"i_name":"QH8G0J9UW2twj7","i_price":78.92,"i_data":"FoqrV9oYfO0xdoriginalVQ5lR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":359,"i_im_id":8226,"i_name":"KFed3wlee7feEpdU","i_price":41.86,"i_data":"dQurQwM63BXbNboz4zl9XUrfjzeIjBFj5G"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":360,"i_im_id":4320,"i_name":"fwQRaqSzyapTBNRY8h","i_price":84.46,"i_data":"YTieWjaPRR3qcEcMMZF1p8SWKjMLybxMaq5WX7g8TwDbb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":361,"i_im_id":1734,"i_name":"9uPt07zv4k0muOmiJd","i_price":85.52,"i_data":"28utdJjNrlyO9ddbe3g3u1Il7U7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":362,"i_im_id":1391,"i_name":"UEfeL9Zx5kgpRtGDbiT","i_price":71.86,"i_data":"RYcwBe0WPPCTfjC8NdKRffsSriCR733sezua284a7W3yb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":363,"i_im_id":4433,"i_name":"xmtGtFPXUDZX9d2TMarr9Fs","i_price":89.33,"i_data":"VoriginaljICQKsGVNJWWWQKwIw9S15tQu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":364,"i_im_id":3905,"i_name":"zQd0y5Nz7NkI4bCxbxkM9","i_price":75.19,"i_data":"TSWXo72RoriginalU7LUjY6iKotCzSgzH6A3S"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":365,"i_im_id":2221,"i_name":"XOBZeRVF7tkf5gPfBFWGkqL","i_price":32.94,"i_data":"lEIvZ46LcwSrHxXx93hN7Njpj1RautqRms6iJQJJ7YsWM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":366,"i_im_id":8804,"i_name":"wu0eZF1g4Vy5j1F","i_price":30.25,"i_data":"gb3HXoGum7dM58RNVwqpkbVwqb32mHSnAANkrdGhw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":367,"i_im_id":2976,"i_name":"ammmvqZaFqTlmSzq4f8lYIU2","i_price":99.73,"i_data":"vkLxoz2bhm6znuorgd9Lv0inaiCNZifxzOk2QRJWty9jfyb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":368,"i_im_id":9828,"i_name":"WkBN9x4LI7V7PnjMkEg","i_price":15.29,"i_data":"147Q7mTiyNIGs5GqSoqmXgFhhScvGGBMq73fBPTJ5RmCejiRjp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":369,"i_im_id":4916,"i_name":"XaP4K9Cx3QFqI2","i_price":50.35,"i_data":"wLF9y8hwvtzp6EIRPZsBOKCTID1GThWSeagnsTDGYtZqb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":370,"i_im_id":3677,"i_name":"xGwqgX1dUF9upg31","i_price":90.06,"i_data":"JPkvHUXi3MpC8nmKJz6EwoHZaO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":371,"i_im_id":1632,"i_name":"RNlGLeD8Hj2nF0vJ","i_price":5.94,"i_data":"J0wXxsof12a9CS53QZHoXRBsiXnpDk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739190,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":372,"i_im_id":2606,"i_name":"Ow13bebZXKyZx2LwzUnyUl","i_price":50.86,"i_data":"iZsC1J79rSEbRESlDy2be56TVoFQHvopjoFMEq53d3M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":373,"i_im_id":4645,"i_name":"PUrCSgoSOWH2UVl","i_price":67.64,"i_data":"D2I1R0SX88AA0PRzQQhnSc1En9D06AyoriginaldXzU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":374,"i_im_id":4130,"i_name":"rW3o2WyHQDzlxkBk","i_price":94.21,"i_data":"AWor4jb6jFt2H7OZIQXvHJoriginaltWs43tQvZU47LKzjzfuZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":375,"i_im_id":1764,"i_name":"3k02bgHbYFY1ZVA79clTWj3r","i_price":62.76,"i_data":"wumgs8zzi4ZmAf19KO9BfrAYCFAcvYn5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":376,"i_im_id":8344,"i_name":"2s0lR0P7tbwYI7evJ","i_price":33.96,"i_data":"L5567QVkuaQmFQUuC9TbMTjNjJsAhsdDk7a26L7ws7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":377,"i_im_id":2793,"i_name":"5W7Cc7utqPUduQH","i_price":69.65,"i_data":"e9w934c2WP5CqnNSuMlOWatn2b6XnmWdZW3ZvWz4AmLTK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":378,"i_im_id":6166,"i_name":"1MyjiSoO6LGEtOaJmppw","i_price":43.85,"i_data":"W4a3BjWm6wZVTPWOHm5RfdxHY92oyOJM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":379,"i_im_id":2404,"i_name":"UY2TQLn18bcrKEs2","i_price":35.16,"i_data":"0IDgRvUtitwxZtxHOgkvj2l4NMKgLYuw9KMLaaAGQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":380,"i_im_id":8898,"i_name":"up0KitPCx9bACH1GSdk","i_price":64.99,"i_data":"BM84lFJuqpkZFyjiB0d6kxBqFQEDYgBTALSY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":381,"i_im_id":1138,"i_name":"O8ZabEStBdi9CsfsVAsZOTvn","i_price":24.99,"i_data":"EuHPDgKLWNnpAAdRKqAQDuesP2iX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":382,"i_im_id":6200,"i_name":"UfK51ydwQANdJ4cqm3JmLGvP","i_price":92.16,"i_data":"Qh8e4f87mD5m6t5436rYwCSydYHV39KIHideEJNSY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":383,"i_im_id":3022,"i_name":"9765InZBeEvVYk","i_price":57.7,"i_data":"QbtQWJ2uP9dlIqqVSnPyMgZyctECSUPv7nAzEq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":384,"i_im_id":3902,"i_name":"2Z8orBZAbJSnamlR","i_price":54.97,"i_data":"HhZTHkZS2K0wOPmE9roru5V40cb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":385,"i_im_id":4172,"i_name":"OiKsF1LwiVA6Nl3eMr","i_price":67.43,"i_data":"x7C4m06Lqhx8AsxrpX6bPg3iNxVCtRHbAA097N4GA6gXis"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":386,"i_im_id":1334,"i_name":"INsC1jNtsamIwGhiCUQ","i_price":49.76,"i_data":"XnIIwDLHcdSeZECLaDQZtclUZIEZ5RDtpqM8Glqs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":387,"i_im_id":8148,"i_name":"IIthPPGZodKEqF4V1RB","i_price":75.97,"i_data":"h73gWBJD6bzTbpYo2aTpYQP5mkY8kO1f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":388,"i_im_id":5151,"i_name":"hFz013C0fFFd6HIMfth8AEi","i_price":14.36,"i_data":"mn5HJlezCRl20m9xGOEaNTWhXG23mmOB12"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":389,"i_im_id":1750,"i_name":"y1nNGFSAwyHreeOjIj","i_price":5.36,"i_data":"ltBbnihmlXUNsCHkHThcbPk9KkVbuRCMnM8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739191,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":390,"i_im_id":910,"i_name":"6dQCixVfPK0ZQ7HU","i_price":50.63,"i_data":"1SIRzFXQ6wMJluYpwMP06uWNBT1giRM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739192,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":391,"i_im_id":4932,"i_name":"Fohz04gcGrCdqEzu4bB","i_price":41.61,"i_data":"5pw8aHCEPArdO1tDCQMuu7y4UOvs8VxfKiR3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739192,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739192,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":392,"i_im_id":4622,"i_name":"ik2QXWOdDZVRSq7RVsqUs20","i_price":53.81,"i_data":"9NF6ilF5I4jmjqsxcpVLdAXWV6vFJtqnP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739192,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739193,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":393,"i_im_id":3740,"i_name":"z6CpY3vGToEeFoGFvVoX5L","i_price":91.19,"i_data":"RHmZPnL3E35yUW4Lc29FFHhysNeFbckQUqmOOJyOZ08f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":394,"i_im_id":4674,"i_name":"BUVXXhD5ZzCR1WSeYwFWC","i_price":20.79,"i_data":"lXjb742TRFNVqvDW2xZyz8LODoYX6OsJj2znqXVqLdAmmo5R7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":395,"i_im_id":2115,"i_name":"I9ZZKPkBhpNQFYDGiuVdR","i_price":98.81,"i_data":"8ytehXGCuJL8Cf6bqbXLyQRfZ0t4gdb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":396,"i_im_id":4595,"i_name":"kbmeHbl7B2dfOkZHsaeb","i_price":93.98,"i_data":"HZ1OUUtsxDrVoriginal6EhYujy268rj2j5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":397,"i_im_id":774,"i_name":"dyA1aReE4XTAMsFrCyJjJUw6","i_price":16.45,"i_data":"DRW10UphhcuHfTxoqmQybyngaWYMCgBpIQ5CqoGH5K1u6h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":398,"i_im_id":8976,"i_name":"EwhuPEN7OiwWF4q","i_price":66.44,"i_data":"eteDueesgNA4MJYHvEYvkjWH7b8de2O1LApmgSsKbBGic43"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":399,"i_im_id":219,"i_name":"fG3613AQ0emkzdvX0oXZn","i_price":51.44,"i_data":"CRi7940vBK9ZkfaGY9F7xxPvGVrbwGrpB2tY4o1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":400,"i_im_id":1966,"i_name":"vsEtCGHKFooVluQFC","i_price":42.88,"i_data":"qwaPqVKTYXGh1mZO5smdFqqgDmJF3xvpa6bpCqsDx3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":401,"i_im_id":3821,"i_name":"jAHs7ejqa3AZI0iw","i_price":81.71,"i_data":"Nx8SkWipoQGE8k5Frz5CCw7opdOuDaXtL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":402,"i_im_id":4190,"i_name":"KpMlCvjAIUPHZlrDYUiVmq","i_price":75.48,"i_data":"eIoriginaljk6hTh3Iq53tM1b2tbE1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":403,"i_im_id":1531,"i_name":"7HOIKWGSTIo6oSZDsUJ1cbO","i_price":79.33,"i_data":"VgP253LcMUCAdG6xiEPmsHrlQ9vemhljqEnHLChDdu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":404,"i_im_id":5829,"i_name":"gusEY3Jn4eYrpelKN","i_price":47.37,"i_data":"GVOxL9se8UhwtRxXiRMBe3sM1VH9h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":405,"i_im_id":1586,"i_name":"u2jGziNyuAucmwjZct5xR","i_price":67.01,"i_data":"6kD7AVavbi3eB2YCsX40RylnZfSqhnO9p4GyQu0qg7LmkZb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":406,"i_im_id":1655,"i_name":"WW0y8QypoznWVc8","i_price":63.23,"i_data":"1UjaVo4ACeqIzuA46v7fzZS2Xb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":407,"i_im_id":1720,"i_name":"VUncQYbai2j1TfQCCc7","i_price":25.05,"i_data":"f2VuMZaCBMdR22UEk3KTslsbzV4sGBWIoNPwWW0tg1QRs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":408,"i_im_id":2308,"i_name":"cFwoWbof5taOcG2vO4NjVT8","i_price":53.52,"i_data":"fQzPMZonydfstT2p1NbdanJxdmOMDX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":409,"i_im_id":8521,"i_name":"6cZx72GFdt25mVc7AjLWjfT","i_price":59.29,"i_data":"bdlrgWD7zBpLImEWL0cTbavHyaDEupgBWF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":410,"i_im_id":2688,"i_name":"wUsOMxLu5uapAopQkE","i_price":3.38,"i_data":"UiyFhB2OA2l9V9ev3u9Nft9gF6tDf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":411,"i_im_id":2873,"i_name":"m5qiy5aSrDRsPjYuK3","i_price":57.71,"i_data":"oLZ9rD4cr1fY2S9AnJO7URTQrMCx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":412,"i_im_id":110,"i_name":"xGC0PGdvKZB4eUcFBXmo","i_price":52.33,"i_data":"ghEcB4sr6gBb69m7hHa9aoJXp8lRMvIiisJf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":413,"i_im_id":3750,"i_name":"ZFRvIQM6XjfVWh","i_price":26.47,"i_data":"seeJnlzLdB7EROajBJkOg6VMxBLQp55PNUG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":414,"i_im_id":1758,"i_name":"av1XVN3DkkMXa5Sx2gF","i_price":22.18,"i_data":"mXGE3o5sojLuBSi1xcbLpDwX6af2j8wzGKACqKMLtb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":415,"i_im_id":9922,"i_name":"YNnm5QEQ0nbjpu","i_price":41.71,"i_data":"aBsUETreBcNewqYJbqm1VkU4gYrb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":416,"i_im_id":6856,"i_name":"WhlA1GNEHgmUvLJC2","i_price":2.85,"i_data":"Rs3n1x9QhvgbrXhPRE0BOTyFPTXEbhtbbUYeIT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":417,"i_im_id":8316,"i_name":"SIJ7JVaRxbcXah7rOAVJQKLt","i_price":87.77,"i_data":"ldjDiDhy81X6hsx5kzg9ehzMnPqbhs1pCzTm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":418,"i_im_id":8728,"i_name":"dTpL52LZU1bQhpHm1n4","i_price":28.45,"i_data":"pY03vvs0vfAigpc76krPRAtj8VYhHICXRusnnL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739194,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":419,"i_im_id":8845,"i_name":"ejvVQSuMtiZfWkcL","i_price":63.82,"i_data":"O98TfVsQ4I3mc10Z401mAmJigxMsfpMq2KW21TKaqtM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":420,"i_im_id":6999,"i_name":"KTxSQAFHRgcgmUXNS","i_price":19.81,"i_data":"SXYIZZ1vqmMU88SlWfV30xo6XfPSWb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":421,"i_im_id":2816,"i_name":"zq46tAk9DESTglVxmU","i_price":89.53,"i_data":"0kA5FCaejbVT2HKktDqf2UERPmUGdxC4PUIv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":422,"i_im_id":4871,"i_name":"wp6OZ2Tz2P63ImEF","i_price":43.25,"i_data":"Cv8Ci05Uy6KQu40IJejlFImdYi1oWD7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":423,"i_im_id":747,"i_name":"h35IrwBUXTRIDtRF","i_price":17.0,"i_data":"18mOXjZ0ZcuuEWPmBGwwZ5md3pE5X1nXY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":424,"i_im_id":9323,"i_name":"colbQo9bGmba9WP9yk","i_price":90.3,"i_data":"hwfQJAnhqkXa7dskgqcp0tCdd0WtpR7Wt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":425,"i_im_id":4976,"i_name":"fgvY6TooB2ZTcJpEV5rTj4TL","i_price":49.89,"i_data":"j2qjCC08GxPgL28Nbvao1iysgUX39aOPwWhwSTdWLjl4BU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":426,"i_im_id":3956,"i_name":"GRiJH8TNFBW4CMeswtLMiFXe","i_price":93.35,"i_data":"OAfRyg0Et8DNyqPlnhMkolRLe4elOiOqEjS5fDdyHXmODG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":427,"i_im_id":8260,"i_name":"BnWHlIWyi7z5icgInv5y","i_price":5.3,"i_data":"M7hBly2AKvCk12qq8OPIbqqGOGoriginalZhgs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":428,"i_im_id":9107,"i_name":"2qNHseYOehC5FV","i_price":82.73,"i_data":"gf2wB2jlysmrpB8cOpFCT9AHv8VedKjtWm9YK02JRDuMd9b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":429,"i_im_id":1659,"i_name":"zz3rluGqjB9PkRZdk8aLo","i_price":97.04,"i_data":"8KVsk7xQuHbU9ufuWLiop5kUgLVHCRuRRLK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":430,"i_im_id":4546,"i_name":"G6cNZtVI7yBJ6k2MceMxl","i_price":73.98,"i_data":"v3dRRD1WhqnhGezZDPznxiIOYbwU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":431,"i_im_id":3561,"i_name":"T2DOnK1ew2Aw3KbAXWvvM","i_price":27.54,"i_data":"NVQi0Gybyf90Hgwt88sJGHFgHsAkXIEEV5YNnP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":432,"i_im_id":5267,"i_name":"fdcXsEKktWhgzsjYmyN4","i_price":10.36,"i_data":"F8mld6VJhPGjG7GTUWdA1GEVMFHBzO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":433,"i_im_id":8531,"i_name":"M3yRj2sHuDvtproRlaVip3dM","i_price":26.02,"i_data":"nqM5kSahecrh6d13OeC8meiUoRGwKVpaR2FGewpzewGodQDmxW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":434,"i_im_id":80,"i_name":"fYq0b2ZyNUanvTtMrrhg","i_price":13.15,"i_data":"4KtYYmFATlTubkemRMuKRDUJGgnZoUJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":435,"i_im_id":1903,"i_name":"yMnutEiPxpbXt1GnoFGd3G3","i_price":58.22,"i_data":"L8B02MunlcBOp94rzAApY4aL2KQhgpp1bCvp80AHglXJBpX8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":436,"i_im_id":7100,"i_name":"Ol0NYDdm3hqxDUN8gt04","i_price":27.14,"i_data":"cyI4tMeDCF9GExobNtkBJajfG7HbZe6aDOjIpaQb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":437,"i_im_id":4093,"i_name":"qRFzkyTggJkNJJ","i_price":4.13,"i_data":"fgnxwCiMaDAWnVgNzCxJstvcSj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":438,"i_im_id":7492,"i_name":"BTeqjDrbpfedOB97sKvo","i_price":50.11,"i_data":"2TfzTNtjlVryv2f7iUq5v6lJnvWVVYnOFdqNPexwfPxj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":439,"i_im_id":4992,"i_name":"FIAJUM8nnrHNa2va","i_price":68.45,"i_data":"rRUcBR7wNXn9YgaDJFTEJiTFDduppq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":440,"i_im_id":1824,"i_name":"I2BEHEOhPMz2haCpROzCfpy","i_price":48.43,"i_data":"g0Ktil7CUSDb1uqi5BNmDo2Fltv1sc3ON3XR8y700ynrf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":441,"i_im_id":1204,"i_name":"7NP93V2hko9HdotpNFj","i_price":19.59,"i_data":"wjN1Of7GS3TwnMZt6h8LrOj3ELfvAn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739195,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":442,"i_im_id":7208,"i_name":"K7vwNusHXXKNci4wI6irz","i_price":33.11,"i_data":"hkZFwNAHuLFaZ6Jj81sIlK1HBNSss9J2zEUH62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":443,"i_im_id":4891,"i_name":"6e5PB50Um2nsON3Cx","i_price":65.56,"i_data":"4IDaUQM8PeHxdkspe9lOIoz52oBaOBtRqcLTRDwnFc5fZjcIL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":444,"i_im_id":43,"i_name":"tKzof5KSuD9KU8o5awGpm0Pz","i_price":44.76,"i_data":"Cf3xRERhb9ieWLY9yKmirJ4ke4OFItwz6R5sK4b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":445,"i_im_id":4826,"i_name":"SVCznCfaGuPwfc","i_price":87.31,"i_data":"VFFDOPpFNxLUA8uYISrxAHSFhCFuExNepzc0H7Evo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":446,"i_im_id":8939,"i_name":"Kp4N4BFiCdROBY","i_price":28.25,"i_data":"D5iTCmZGdPgnMCPaB1M5LKRr1rdrKvs9Yxn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":447,"i_im_id":4329,"i_name":"GIGa8AU8vcUeFYHD2w4Am1","i_price":10.31,"i_data":"c6noeQNAKUlb9FBgebQcB0iyydP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":448,"i_im_id":3728,"i_name":"TG2pqiRoYYAg2Phu2x7zbI","i_price":99.93,"i_data":"nuoplivMR6rrxbPAjP4joriginalGsXwXW5wJYCUg7k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":449,"i_im_id":1344,"i_name":"c69Wxuv2337UfUHrWDpkW94s","i_price":76.03,"i_data":"jgc62L5VAf5OzEC2BxSE3UsfjL0B13GpCRREPQQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":450,"i_im_id":364,"i_name":"TI4rpz5Z8W7YeQofKFjgEBpz","i_price":40.57,"i_data":"eBfCXMSAs4FwjHZLntoVoOLsFf8YO1K9bCeP9BhEqeXkJvjQyK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":451,"i_im_id":4973,"i_name":"ZtBZmK0TesJqpbPgG","i_price":71.26,"i_data":"SHoriginalAQr3Y7x6GGTfQqzJLtXFHtj5l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":452,"i_im_id":7798,"i_name":"UoNwKuL8Pd8jxsMJh2AboNM","i_price":52.72,"i_data":"i3GJoriginalNqh0tRz27RN1z7xNHb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":453,"i_im_id":295,"i_name":"Xba6Npti5yIfU6qq6Uh4R","i_price":91.89,"i_data":"huMWMCqteTHFEM78rUuv6bMZZ4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":454,"i_im_id":177,"i_name":"nTETvxx8Zx8rnPNO3eMQpNG","i_price":72.1,"i_data":"GHxUqoAtTFcaUswI2ym7ne5xTf4l2tc0jch7QbLlF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":455,"i_im_id":4683,"i_name":"1FchvojM13bOJ5dKsMpvqCE","i_price":12.47,"i_data":"3P5NRxaS9m993VWooriginalzNgQGYi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":456,"i_im_id":4419,"i_name":"ozEs5xfkNSaBSctPlMAXfLo","i_price":87.64,"i_data":"tzRoKCLvUbgJY2xTJxfIkfyG607nkh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":457,"i_im_id":3310,"i_name":"octuE87qAIFUrn","i_price":56.88,"i_data":"B0qbvybANit9zhfptCCmOOq2Hmmlwi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":458,"i_im_id":1004,"i_name":"714mrZnEovj5X9","i_price":91.37,"i_data":"xocT5m4yjTRzpjDPKhxUP1gvBYaqnUkkANVDsu3lcWZb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":459,"i_im_id":8629,"i_name":"WAWzxImFjBNhFgaq","i_price":80.95,"i_data":"pgFqDGgdpGluOB78EiliMh62Ieyf317hjLRzlYZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":460,"i_im_id":3792,"i_name":"ndv6b86rKp9n2cNX","i_price":47.78,"i_data":"K6gzf6UlPZFmuOoTXDvSuOrcwn9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":461,"i_im_id":607,"i_name":"Ts2tcICOYSfqLi","i_price":88.85,"i_data":"9gAhyGQSpEmsx9o8PcWhGFKKV1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":462,"i_im_id":1669,"i_name":"KOh5KiTnOUhFm9P4PO1","i_price":4.51,"i_data":"z9XicmmBre4fsQuS5qtVEjizUqZByX7v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":463,"i_im_id":1654,"i_name":"wrYaCoZvq382kidwns","i_price":84.59,"i_data":"Dr8snhBQZ9YmuFVWDOUHIIuVAwtYm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":464,"i_im_id":7507,"i_name":"7Ianh5mGmeAOTw14r","i_price":45.0,"i_data":"originalLOwWpnXxDagW7GTHdFH1QP4QYIbhbhcKe3cli4YUh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":465,"i_im_id":2392,"i_name":"f2UsAY5ZP9UeJwk","i_price":13.44,"i_data":"xC0EalvZwC6uikSNaSXcnSMU6a8eDGwMMP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":466,"i_im_id":1780,"i_name":"LmImUmfxTOZ6v7Xjlh","i_price":6.11,"i_data":"eaHWhg0Bl5GhdK3ygaIsrwzh7jPmR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":467,"i_im_id":216,"i_name":"PaX7a2ZeCYLBeLo0Ywb9QUF","i_price":21.31,"i_data":"uA8hXQUHAJ8ACbl7osELhe3HkptwyQPzrkqYMNNky3ke0XScF7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":468,"i_im_id":8806,"i_name":"IsJ44FV3wlOxPLFy","i_price":79.13,"i_data":"5MXmj8m7JVDcEuOxrkmlwMOHk40oS07TGD0qWAflt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":469,"i_im_id":9007,"i_name":"uybUE5WkGAGis3iz8T7y","i_price":98.98,"i_data":"uSwXQvaENLWr8BbbimPgc0Rbgzk7I6K7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":470,"i_im_id":6022,"i_name":"tpxXav2iTngSHqySX5mRDHD","i_price":27.79,"i_data":"iKdsLsLojfPCDoriginalTxi91BFT5Bb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":471,"i_im_id":4692,"i_name":"ObvRXd5zbUB6wcIYL4","i_price":58.35,"i_data":"gpTDEltkfu1g2aRsMI4UUkJ1Xy3G"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":472,"i_im_id":4542,"i_name":"LAu4X2aPmXJdUF","i_price":45.67,"i_data":"33Ch0qBq1HZQjR3ePetbztOrvxnF6ifz92"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":473,"i_im_id":2884,"i_name":"daaJtWWiBE4jEnOFIRIQ6vh","i_price":54.24,"i_data":"JTPjk5BZRcj5C7It9g2uEeiN0xPY7QH6aJIUgt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":474,"i_im_id":8166,"i_name":"7tUuzFlUUdxJLk","i_price":88.57,"i_data":"oD37ivohkMxtoriginalBw9nWiz4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":475,"i_im_id":5679,"i_name":"WXc918pVzGQoQskWnvnNI78","i_price":57.05,"i_data":"ocZOaKaInWyo9aHgi3GXI2j0f31nPvhKMjIGZmPJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":476,"i_im_id":8448,"i_name":"ZzMdffMv8f54bHMk3EX","i_price":94.7,"i_data":"RTORneVqdRMiLFPY9et7NzeIB3cAYqJVCzqrsy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":477,"i_im_id":183,"i_name":"ZMxJHnz4An7m4C3LDf3Af8AQ","i_price":20.17,"i_data":"auGWqcput2W9llQ8BWaHaBX5m1PC2ZJnTGrfuDV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":478,"i_im_id":6397,"i_name":"cL8iBoVhGmje8H0uzL","i_price":33.07,"i_data":"gRF2x5QYIuCoK3HET9ixEvcSeQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":479,"i_im_id":3299,"i_name":"jnVHFkvTmqUXCm","i_price":23.13,"i_data":"1o9vHuuSfMwg8jqNPwfI0521WKzz6IszFtBMzlCU6Gbu854u"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":480,"i_im_id":3445,"i_name":"ZxVaMV55c2scJStgn8","i_price":87.5,"i_data":"M3oLHo6vbgmN3mpzb5LFzsKOyZXoDQ5cgks"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":481,"i_im_id":6260,"i_name":"DMHthiCcfdutxyaQfJt","i_price":49.55,"i_data":"ANZhnvm2HbJUN9kni3RaCyo27H8p9CgrpDpuob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":482,"i_im_id":1765,"i_name":"6pLDbjXLY57HlD","i_price":39.26,"i_data":"kjDj91rhDJ4HHfHBEfB9JsRBNZz7cMz2j"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":483,"i_im_id":3278,"i_name":"4WBmUyeTwKCBUMFa8Ku3Ini","i_price":76.11,"i_data":"Omd2mb7WMD4FbaNgdDeGqJdqYFFY5kzQZBhG12pIn2dK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":484,"i_im_id":3493,"i_name":"tluulKWRrloEkH","i_price":22.68,"i_data":"L0DNw05JZ1URd7228mF2BcRVw99rnUQQwzb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739196,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":485,"i_im_id":6532,"i_name":"3ThKi5S6Cc5ifN","i_price":15.07,"i_data":"75Pu4Vcc4u2rofKPuQYDg79Nxb6sFnokPGiR7XSwOCD9Oy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":486,"i_im_id":2604,"i_name":"3R7WuTbpvZUb5aH8onY","i_price":47.75,"i_data":"qZPxmKfx0TPVUCI2kWOFOHDEvw7r2Jkkh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":487,"i_im_id":8350,"i_name":"PCyvr6u2zEucFvBo","i_price":97.69,"i_data":"OEhtygntHgQXXidWCgm67olyj5cypMyXfbteVxZu5A5u"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":488,"i_im_id":4424,"i_name":"PMHOGU4zGtraGFlOYSc7R9","i_price":41.27,"i_data":"f8pcrmZiZrCkIhoGHoXkFLywZ6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":489,"i_im_id":2377,"i_name":"YDe10m758fsuaTG1","i_price":78.1,"i_data":"oUM1fFaksM7tNfnO4f4VHpzRUnRayt2HRMKA3YKOS6oB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":490,"i_im_id":6880,"i_name":"3jmHp42gq0Xbck34hC","i_price":62.22,"i_data":"pQ1pFkrvAh6U27hC0dGQskGnvSLDD3PtNR0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":491,"i_im_id":2703,"i_name":"gNW2s6x8BY3CnQpaMgDDJ","i_price":57.29,"i_data":"g1RdD0K0fuQwea8Hsybknw6hx9ab6icRZT4MespCTOdvl1HFU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":492,"i_im_id":1297,"i_name":"qMbOMkCscVI3i275oLoA0w","i_price":90.16,"i_data":"Mo29zRqHNpX0ARJoV12pmuhXxnQQq0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":493,"i_im_id":5587,"i_name":"tHjOYdwyt7M5fL4hPuPo","i_price":54.75,"i_data":"MY2S0iAswkfERVVFtGvDFxWvC9rL9FOobrAc7jqt4i29fcQtx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":494,"i_im_id":4070,"i_name":"1HO2hmGtPbnx5eqKByP","i_price":92.52,"i_data":"8w1CPbXpIo0YmoG8rUTYgGIqoEnmWKQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":495,"i_im_id":1596,"i_name":"AuIpQu5q7Y2xx0","i_price":93.97,"i_data":"ADumSyHWnf1GukiBjyZGfwN7l88PhA0VsN9h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":496,"i_im_id":941,"i_name":"Az6rlX7ZwlOkEPaZM","i_price":48.48,"i_data":"La9vnvZZMzLTlkfUDpl5Z3QSMTG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":497,"i_im_id":8650,"i_name":"CzOQqWCoj6S5vfPc8dT","i_price":85.14,"i_data":"VQbslJI4bsyBReVi7qeQLcDra0YD6xzKJb9ArEUqVj8IXVAH2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":498,"i_im_id":9086,"i_name":"x0lK3HF94lK99GWIKXw7avy","i_price":78.01,"i_data":"Yq45zZ6UHQbSliOkN26aSmCqomVvvhla1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":499,"i_im_id":2787,"i_name":"phaRh2uo7SAM3S","i_price":55.68,"i_data":"OSitFJfGChostqkAVSPXoQHmcrzjHhmI65xKqu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":500,"i_im_id":2036,"i_name":"VHaBhBHq2MIiDnP","i_price":26.72,"i_data":"PRW5cgM9bBe3YT3W57Vt1IcIyFjpluStmoWEH3SQH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":501,"i_im_id":8177,"i_name":"IC27ylaaiqgLtoufN5v","i_price":81.34,"i_data":"pxnYLSKjRMfSaAXZeVRhOf9ods6fWZjbomij"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":502,"i_im_id":3718,"i_name":"vAVkAgxqXwDy5bwemAkeT","i_price":59.62,"i_data":"6F4eZw3nwb3zysRWn44McRPquFf4CVgKxHZhg4f0wRtb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":503,"i_im_id":5925,"i_name":"ogO4DXOCOmZXKxoJ4atHn0","i_price":88.7,"i_data":"Zpu5ftINQHOkgfr7SGWTfBbjNnXSPK958X1HILq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":504,"i_im_id":2472,"i_name":"E6dSpkzC7rgMw83pQl1","i_price":26.57,"i_data":"P39zxgG5L6t7i40NHtSQvMSm4exgCYLll"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":505,"i_im_id":8153,"i_name":"sc5aEYg6zhHbgthY","i_price":30.04,"i_data":"Sa8df0H5bJrmUofd1xmaCVpF3ChSqyO06x6fponmDgUyG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":506,"i_im_id":8662,"i_name":"WbyoPckqqS3vaaX988x","i_price":22.94,"i_data":"lOTkSqQyPJeLImIIYzg6feTNMYBzn0ojhqAMfB0wWqMAV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":507,"i_im_id":4094,"i_name":"stxqwGJbgJeLb1mfY","i_price":25.79,"i_data":"0aDVkVG8do1EMMWOrVtrYHu36S2VONeh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":508,"i_im_id":4581,"i_name":"fUk27ftwVIAveXDvilM","i_price":27.65,"i_data":"ad5jwt12QATzoAfqGoriginalXUYxlU217X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":509,"i_im_id":4363,"i_name":"a83PNz8oZNDVGfLV9rKT0Tsh","i_price":57.93,"i_data":"sFwZZHI5nZK04uMh3HSYPp9woW6R3baqz99b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":510,"i_im_id":3492,"i_name":"MiRF9Bkua7JohTmax8kzHKG","i_price":29.19,"i_data":"XRnOm9Rg9JaZBgoCOq5wLioYAbaSIoToMjDs4WIljuwI3N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":511,"i_im_id":7914,"i_name":"dkyoPwq0OS7NFX0noKC289","i_price":38.2,"i_data":"lrQ1k6wKQmk6CiGyDQySWYeMemjhmut3IWw99V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":512,"i_im_id":6463,"i_name":"TtCoQZdOcnG7Jpjt7B3H9BJ0","i_price":32.75,"i_data":"StsmqKjLNvZakjV130mxUbTh1qcf9VBEsCb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":513,"i_im_id":2351,"i_name":"nyvE9NFl2vmvi2mzHMwt","i_price":66.45,"i_data":"UWqzBWAFnMrxe65teQVSQxP7OM3Q8emV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":514,"i_im_id":5436,"i_name":"8gxCwhG3ZI5uS4CUP6uKA","i_price":63.09,"i_data":"vViTYXJLCLXRqYUzfQKnKech4BkwTjCVf5TdecA7ZASPWLqdCm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":515,"i_im_id":4931,"i_name":"9X1eY230dGLgvtoSxZIzzw","i_price":12.08,"i_data":"xIV446YlnsVsfzhFbuOxdIwGOZt6yM9AMA4pRV7P8dyfWTU1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":516,"i_im_id":7490,"i_name":"fn76aJacxbh3RqZ060qkvxa","i_price":29.59,"i_data":"rCKiOH7mAzfaEx9jVaVQMCxi5fT5VQnSzXb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":517,"i_im_id":3884,"i_name":"FlMrnPDhi3yIcQyPCH3gTPQ","i_price":30.76,"i_data":"RTk3eGQd9a6DDU9vFsuDaEmTyHnpE2uwlpqrubYBrMaB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":518,"i_im_id":2188,"i_name":"pmSlPgZ3UbACR1YwKx","i_price":74.25,"i_data":"xvSSZauiJpjS7QVutenAcDfYWOyG9aAADi8NzHsZziCFl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":519,"i_im_id":5199,"i_name":"NYf4OsHVg3Y9oQaKEfi","i_price":27.09,"i_data":"bzMkepqeJ2JtJXZH7FTbCTBmFMcRnY5NkCMMyqJr4PYlBqlb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":520,"i_im_id":5209,"i_name":"8oIENyH69O9ija","i_price":44.74,"i_data":"hkkwLZnBKt2M3K8hCmvg8O8Eoniqu4FDLLbZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":521,"i_im_id":6359,"i_name":"HXzvDkiu7s7lpZ","i_price":25.65,"i_data":"s8D9GPGGlLk2TVkkbZ9TmPyrgoBdvSf3YBkApRyPU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":522,"i_im_id":1502,"i_name":"aUceCKfUdwp9dv","i_price":33.22,"i_data":"AexePxMAMqohN6QY6xjuHAEgjKG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":523,"i_im_id":5180,"i_name":"Ao65nk6BN9RdSjIvq7K","i_price":43.62,"i_data":"vawf3RtPTedKrCqVNHxDM9Sgb7sjoev3jI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":524,"i_im_id":707,"i_name":"0cwtAiCvQwY1y2pLMTtUq","i_price":1.16,"i_data":"e37TXOkMQBhw8SPOhO0OUQOeUo0kmqZfhh4FdpyHhbkaU1l4N5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":525,"i_im_id":2083,"i_name":"3tiCmI8H2Azy3QBzrXpm","i_price":75.63,"i_data":"bu4KrnnGKHKdsTyqkzV4Dy42mGdjvpGHg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":526,"i_im_id":9069,"i_name":"fklohpdUdcUrvlmPdx","i_price":56.22,"i_data":"SCYnEzbkC6sLUNHR5fBJ3fWgjBqnFBNn8HeavPLXXm0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":527,"i_im_id":8940,"i_name":"87zWFcjqF35LYcVt7A8","i_price":30.38,"i_data":"2LOlCx08h7Yy9bbjysUVA3Zhqs4vfvqodVmcmccTVmR1fqumng"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":528,"i_im_id":3547,"i_name":"uW0PG25fTkw9Rx7IMWAd","i_price":37.66,"i_data":"e9HhtAx1sauHkQ0wIinKPtPhfxCWLMb5n"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":529,"i_im_id":7443,"i_name":"nN741i5RlauzTT5","i_price":98.08,"i_data":"OB26t7K0utp9NZd9qZCpNQyNK3U9yB5C4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":530,"i_im_id":7351,"i_name":"AbRxrcWgjKMt9bog","i_price":20.96,"i_data":"gmzrFpPfk3aOSOhVztKIs8Q6Yfle1hgs8INY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":531,"i_im_id":6278,"i_name":"ohl2bd2nFU2jBg8","i_price":83.93,"i_data":"2AXmkjfwW6ShuwM9FRQgqFQgkOUrEWs1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":532,"i_im_id":3714,"i_name":"mb8oJBj3rEctyGAoWvseC","i_price":51.9,"i_data":"YM93J5ImMtNI7D47HKMc4RCMlT6E9OlZK7DbP2Kn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":533,"i_im_id":4961,"i_name":"FtkTSk0SxuuEQpiuMzU7","i_price":21.92,"i_data":"06wlHPuHZNjQjFL68LBBsKpw23obnNb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":534,"i_im_id":419,"i_name":"qC10rKozjpso8r6dxu","i_price":7.79,"i_data":"chlmj71kguaQM30q3eiMhtB5HgqQY5Hz7BSNf7BUJXqohhEL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":535,"i_im_id":3332,"i_name":"nFCPghrtwrKldJ7Ucez","i_price":16.31,"i_data":"to5gdNxTaF4daiIKBI1nOwS0zru2LKbHVxIJ0BNt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739197,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":536,"i_im_id":6943,"i_name":"kK8NAPIOLrysH05hpuEcf2K","i_price":27.13,"i_data":"JhhD0qhdCdvPvEqZk9GoriginalLpSYAHx8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":537,"i_im_id":4973,"i_name":"3rnVwM0CkS89krQWfywnndl","i_price":77.26,"i_data":"C1CSJY6LuHbkFt3vKXUHCYDejMZrO6I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":538,"i_im_id":3517,"i_name":"B5s1E8kVO5zlpNEg5Ola","i_price":35.44,"i_data":"3Y9cixukxtQcsIF49KbRXlCOwxLCBX7kSzcj05o2qUfYb2WYc7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":539,"i_im_id":6929,"i_name":"4I376OEcNXQc7lam","i_price":80.47,"i_data":"XUZm74Z9DkmN7ZXlfNl26Xy7seePb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":540,"i_im_id":3696,"i_name":"RPZd1QfD1Oz4pvQWTcEl","i_price":73.56,"i_data":"pUCqHRE4bACJvfBkVc97VWfhVlMdaenxaKbZUWzY085jGiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":541,"i_im_id":2861,"i_name":"bmSINAUvvNcdpRYZhO7","i_price":58.55,"i_data":"fPdXX4u3RtudnPMK2ScSBBsAAM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":542,"i_im_id":7525,"i_name":"9bNV4WMYAum1TwqYCT9XuZ","i_price":27.21,"i_data":"p8qlQp3kHhSflI1Sm2SnsjKbJwIjs1PZ3E6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":543,"i_im_id":946,"i_name":"TeYu1aOQJtreVBwcB","i_price":64.69,"i_data":"4QSDhDpZRcoe8dKoCcZyTWPzNN9hEXoBmUgSr2bOh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":544,"i_im_id":1470,"i_name":"G6mlrxMRhCcG2r8","i_price":63.52,"i_data":"8OIslohilPtS9XF5FbCQLHdJ2YDpv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":545,"i_im_id":3939,"i_name":"WDnV2Iw9s2U0hZB2yN9eeJLH","i_price":87.02,"i_data":"MTSncxbSWxWv83BgudcmmQnNJqUCHskDhmkWprGFp11"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":546,"i_im_id":9418,"i_name":"Hntwm3wq5XLM7zA","i_price":19.64,"i_data":"UYk1mgGavky6wmLdGCyqo8R0I4vhyN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":547,"i_im_id":3501,"i_name":"gWXcbNTDbDW4pLxQN5A","i_price":96.15,"i_data":"O4784Yk01r36BM3gIkKBXoLaFlysbL1OKcQDnKtBW0I8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":548,"i_im_id":6320,"i_name":"NdVlS2f1LYTVisDUJL","i_price":94.54,"i_data":"27ZRsE1BvLMC6qOO0L9originals5UeIoNXXHJrvDzPe9sxJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":549,"i_im_id":4042,"i_name":"nhxGqyJtcmp0c2GS","i_price":9.96,"i_data":"Wfil1NCLRBZNST6TizOavMGknZ7eufvO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":550,"i_im_id":8989,"i_name":"NZsqwirp5YhptCqfuu","i_price":72.07,"i_data":"yTJmog3QZGPavNowRff2XZOiRuKQRwMM6yAjJb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":551,"i_im_id":116,"i_name":"c4HHPES3FZpMSJA8XYUeCPq","i_price":31.41,"i_data":"GGbaGXoPNEztkhggO7ODB4VPMEsCCcjLOUgpR0KNzMogQaLP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":552,"i_im_id":5731,"i_name":"0PrMPMp4rmvXTMopEG2WKgpo","i_price":93.29,"i_data":"sY0IN0D3Q7ePdD8oTivNZCLwCOFeYNqDFFmHONONsPb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":553,"i_im_id":4190,"i_name":"LGiFx7TXtSQ8qMPxhR","i_price":79.5,"i_data":"sOxKLVXBj51G117sGnfeYQRqE99ZQayeiq5IRIkyOmgjAbC0tZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":554,"i_im_id":5456,"i_name":"DpYMKuCfq2CWeLvMC4sZ","i_price":21.49,"i_data":"bCfBoTi539Vamdb4c8JHgQhjHreNNgL2qOUV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":555,"i_im_id":6390,"i_name":"fmvj8i2csSbNAJP0","i_price":65.65,"i_data":"UrdZ8CPdjoAC51HALl89n84Tt78sKMxxb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":556,"i_im_id":2151,"i_name":"vbtwPamTB1bj8X","i_price":14.61,"i_data":"HTpz0IDI1K14lYCJWIon6dB8kKmH6JCeNJKqni8xru3O2r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":557,"i_im_id":1433,"i_name":"ImtKvvCBpCcU5lP","i_price":67.06,"i_data":"wyDzC3XwEfvcJjFZ9DcqayISQIg3XCdZGN2VDSTn9Y86szo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":558,"i_im_id":1988,"i_name":"c3bY5UHCcUeeL3kP","i_price":44.89,"i_data":"0XLbr1d3xZhsTuY7m4f7GBLjGTf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":559,"i_im_id":8814,"i_name":"sgc3SU66nhw24xmWNF","i_price":73.4,"i_data":"58R7w7cy8kTuYoXdaieN2Bhc38V6Lyj22Bk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":560,"i_im_id":5155,"i_name":"smwbAhBCUACd9sdJFWz2M833","i_price":43.65,"i_data":"YyuO4baazXzgTxWYNae6HCSGCNM909sHaov7rOhm2pT6CMU5ZM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":561,"i_im_id":2003,"i_name":"F6iHs5PMGRhH6v","i_price":26.4,"i_data":"rHYTLVRXg9trtDTmFD27jTSSw8lzyI3HowSbjbNgIMZdhvK5AK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":562,"i_im_id":8435,"i_name":"pKkHlorQinRSRQJdZ0fYM","i_price":83.24,"i_data":"Ye8iI1KqBSxEOjq1voF55Fm3N5aLtdEn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":563,"i_im_id":2993,"i_name":"uuB62majnBjKB9Lc4","i_price":34.79,"i_data":"uns4nYqnoXlaOIamwEugfGAyZZQ279X2N54zn8RT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":564,"i_im_id":9852,"i_name":"z2axjEQyGHLyCNMi9aF2TMlA","i_price":56.45,"i_data":"TRxvrseFPZViNq4di8sxQUHBa223Yo5WOJwpJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":565,"i_im_id":3440,"i_name":"Ghu9qsGonYemNWb","i_price":6.11,"i_data":"ZsKTpSSXIT1MmY6iEpDEnU8b0SfmErEvaTlxGmMIT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":566,"i_im_id":2688,"i_name":"3KOpSYDpYfEtLhGRgYVix9V","i_price":77.61,"i_data":"XY3jG0qOaUJi4LYRbqJur7ziLiEKi3zdH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":567,"i_im_id":529,"i_name":"5zjAKxhqJBohOEytNInJhkA","i_price":43.14,"i_data":"MdjMswbNsBBffFKhaARIw2ANSpt4SAh4gx7B2x84YmS0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":568,"i_im_id":2793,"i_name":"Q79Rmfepqv5lzL","i_price":44.18,"i_data":"2IEmkQm3pH78O2l7XjKqCJB2y7TzHiYlKSmjXAcNQMGGQz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":569,"i_im_id":3730,"i_name":"FOInEELTDAC0HdOXrR","i_price":90.82,"i_data":"ull5zcjY5NHgm2Av0sDBNQnaDhUQu31J57CJ1J"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":570,"i_im_id":8090,"i_name":"bkNT9eFwou8H5Ibrp0OTQIEK","i_price":1.95,"i_data":"oUbHYsOgpJ2DysUuhGFB0MVtzZS8fuKVsi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":571,"i_im_id":5472,"i_name":"TJPSkSKyPbcxt4RM58t2JhW","i_price":42.46,"i_data":"roriginalpZbEG1wV3TzIqa4yVMg6gb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":572,"i_im_id":5433,"i_name":"K2AVgWNhEBFtUfMO","i_price":77.4,"i_data":"wRDmXGWXKyriPNqmSb1RzRFhBCdDYpWipqApf3MzN4eaSH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":573,"i_im_id":8260,"i_name":"fwe32cDW2S6x5g9tYmX1029v","i_price":30.67,"i_data":"vUIOr5FusLroNFv9UPIqn3z7WYKonGQMWYup"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":574,"i_im_id":3803,"i_name":"bBeIYE38Pf8orcL7","i_price":42.48,"i_data":"mFn3YhNf9XmXYlJEY1O9595VMAAlAyCtU91bBrOvuebAbi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":575,"i_im_id":5874,"i_name":"1rwBIhPfllzfkqORzc","i_price":84.3,"i_data":"mvDR4vMU9fcDdG4LJaJMK0bFSdoriginalz2P4Piwt5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":576,"i_im_id":385,"i_name":"GicoS1qyqPsWMeth","i_price":48.21,"i_data":"RbYTbWgrJtOlzK61OPMIPNG97G8wrHrtFBLYVJ6hqkSGb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":577,"i_im_id":6052,"i_name":"aNQ9iQNqbBKfMXzTUebiM","i_price":9.06,"i_data":"oLSV2u1aWdMm3hCrLJKIF89cq7FxwKqiKKyw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":578,"i_im_id":4302,"i_name":"PKPztQnn95S3qiy1X2YM","i_price":18.76,"i_data":"idKSzN46WUXKJH75tj7Veqg6LUB2jAgTYMCKF42CPtKNU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":579,"i_im_id":1907,"i_name":"YstdxK2JW8ZzU39hm","i_price":3.83,"i_data":"BVPWt5M33Q0mglbBIUTu8BPnLH7mNLQX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":580,"i_im_id":4379,"i_name":"qjRCy8w2SpIYvDer3RAqu","i_price":86.12,"i_data":"xYRotZKOU9lBe9xSENu4C77WD677biALGeKQmUBzo2CPBb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":581,"i_im_id":4470,"i_name":"12UAZ0wdnLEVVQpsh0BT7","i_price":4.34,"i_data":"vFup7SxVvTW88SufYnARml97LyaUE9bKjFZhVLsCuKXXR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":582,"i_im_id":1892,"i_name":"Ph5tQXDBnhWbTjJ","i_price":99.69,"i_data":"xoo4EgfnKwzYiu53EWOgatqcqG6Lq5Jv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":583,"i_im_id":2179,"i_name":"O5sn8AMNXAxcF3KpyMJXZb","i_price":22.58,"i_data":"HAAkQueOOppaWymqDkniiw8s3y009R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":584,"i_im_id":758,"i_name":"CP5vTwPc32OeGLsl","i_price":37.9,"i_data":"Yx73aTCO26GkVoS34l2ZXnuriwTlsDYsHowRGys"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":585,"i_im_id":6243,"i_name":"ViIIoW5iw3jjYY","i_price":75.79,"i_data":"3cNWjMNM1mnrnLfDqNtbrrt3TLeSoriginalOb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":586,"i_im_id":7561,"i_name":"AxkjceMzM0Ap1FW","i_price":84.37,"i_data":"OgaCW4TGyMgGbF4PKNUjv1Pl7dG82akM1vQrc9389KzADvV0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":587,"i_im_id":9584,"i_name":"rWWNfX5yWNi1d5j7Epn","i_price":36.79,"i_data":"Jx6CuFY4lMj4ojM28UIg1eLdMfW9CftFLsFun6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":588,"i_im_id":917,"i_name":"xt2xS7RTO3djz9B1dsLt55cu","i_price":41.6,"i_data":"hPfSfqSvMNoBGVcVBzwJgB1vIYo9cC9PWLFjDPqOOQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":589,"i_im_id":2624,"i_name":"LVg0iiaxgCaEEVqaDmwoZ","i_price":29.13,"i_data":"V5vP3lka3yS3WQTOyJ8Vojjj9adBDYr79lappSfnplGbxP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":590,"i_im_id":3372,"i_name":"zbNu1xxEjde6HW","i_price":77.68,"i_data":"C5dhjuzL2tBKmJiTMNJi7ZarONiNNr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":591,"i_im_id":2522,"i_name":"2HV4ClRg4DjvVW7gk1Md","i_price":15.52,"i_data":"9ENBVidjPF7dqoriginalnvaNz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":592,"i_im_id":5138,"i_name":"GZiE22zWjXdVKuPGh","i_price":14.06,"i_data":"5kLV32RIOw3JyfneFjG696KPyFGZ1hG1RsPKgHEn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":593,"i_im_id":4789,"i_name":"aEBQJ8fKJtHEKnaVi","i_price":89.09,"i_data":"ghcRS7svtIjFZ3htaO9auDCw3cIhfLMyHStVfJHkSQuMGDtxP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739198,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":594,"i_im_id":8320,"i_name":"L7LAPsZxdrjNdpv","i_price":23.21,"i_data":"bw6sn6So8q0dNMPRa4RoJ3OUtqtiOH3hnv9M9sNz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":595,"i_im_id":9613,"i_name":"lxQrkMtX6g3B9PHCYT6mjT","i_price":24.3,"i_data":"n6eGCCZbYG1ZVjUZAHvAgtMiiO2eZPdtnKHPVwJxkEIhfOY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":596,"i_im_id":7128,"i_name":"u4iOHwOb92rkaUAEmltGNgP","i_price":47.96,"i_data":"ocqXXtdu7C2IGwtZKTEXSCRsuZlDB0Bc3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":597,"i_im_id":1105,"i_name":"K76WylyZECiima4OFMZhfMYy","i_price":57.48,"i_data":"hIr0tFrkXaFzIDq2LssTP4RlyRRqoxO9pHCnoriginal"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":598,"i_im_id":4827,"i_name":"D73MrWHMB6sVfCMsIDZ","i_price":69.58,"i_data":"YTRX6o7Wfuy8VHS3jrcbzlFXQnjzrSDN5ietvzbUKTk84UG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":599,"i_im_id":387,"i_name":"cy3bHMkkHU3Kw4hMefmsgGpZ","i_price":23.54,"i_data":"xOxWQJDbS3dCRHnaXu4REkl2W9X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":600,"i_im_id":412,"i_name":"wuqKHVboW6oAsnd59xKtp","i_price":8.59,"i_data":"sG5BIhEutAz9w2m4JBFsVQumFTgxkSRPl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":601,"i_im_id":4009,"i_name":"HcwWn3UDpvEj4RUnInVLK","i_price":10.47,"i_data":"MFlcENfw1kbBaQCZHRzCIMqTdZfzKOTZSCEGPs2AraCc9n7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":602,"i_im_id":1759,"i_name":"Y6jvY7foR7Sl3bzeyJjhAD4","i_price":14.0,"i_data":"aXYao4kyszjr800jjGhHv8RmDrI2wrkTnys9TMcvWaN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":603,"i_im_id":3015,"i_name":"rx5Nrmnah3H12WtEpow","i_price":57.16,"i_data":"WtJOuk0e67S6umEO6OJO2pg0c3moriginalwAcBdmX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":604,"i_im_id":3448,"i_name":"QGdgYHj5LhGDUvtofp","i_price":88.6,"i_data":"dxCrkf77LRjLK0i3SUJ3uAoF7GO9RqMhaYFlK9Cb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":605,"i_im_id":1914,"i_name":"CncETr7GBhksF5BnNb8Z","i_price":45.04,"i_data":"tal9eOG9dHTQYKXdDoriginaltP7x2gCvHhh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":606,"i_im_id":2324,"i_name":"iQYfjb1Z3NExsNab2B5TL","i_price":61.17,"i_data":"TVTtLlIVkqBxKcHEciu7q5DbotiWqckdFR4aTxDvvTllQ9KNW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":607,"i_im_id":6234,"i_name":"uULdcnAIUFxDkF","i_price":45.13,"i_data":"JI09Iz6dyn8xNUuQa0cABmyAWmAfZ5F"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":608,"i_im_id":6502,"i_name":"t3oHSHrOOQMVEP","i_price":78.27,"i_data":"vnzfbUkMoriginal9aFwCDl68Y9b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":609,"i_im_id":7784,"i_name":"gJH5WV0yMvzQsFfQNO2g","i_price":5.21,"i_data":"LRbFTqBqTwifjElfNPC2SyVj6IrNHTVqCUk2fKOyQkY3f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":610,"i_im_id":9324,"i_name":"7GUxd5Db5DvYnY","i_price":33.1,"i_data":"1yoH3FwO8RyTrMBXt49reoriginalKDu1j"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":611,"i_im_id":3335,"i_name":"SJend8FY7yKDsn2X","i_price":90.81,"i_data":"T85w2p0JHcCQFXUmhu7GDmHL7UMfJV3p1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":612,"i_im_id":3384,"i_name":"R5QwgHd4HKdbOZNZZNEle","i_price":86.44,"i_data":"EitYWMgqrzJTtD3re009Ln7gLGOnKWlTW5EjJUpUqfOOZrp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":613,"i_im_id":5212,"i_name":"seU96HzNN0fwMfYlDJplU","i_price":94.91,"i_data":"pHfyUlLW50xCGLwctYHb2GkRH4pzUT1YCTFdGs4qALLCx36"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":614,"i_im_id":8951,"i_name":"NuPEY4TO3xEhJtyRAJM89","i_price":25.88,"i_data":"T7zat9v2ptCNqiAfuSwiQVW9QkKHc1qZOpiYIUj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":615,"i_im_id":3449,"i_name":"gc8GbXA81WZw7F7W2vJ6","i_price":90.77,"i_data":"YZoYrrz9ZYMjjM3NR577G5WjD0bo2GTmH1Abob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":616,"i_im_id":70,"i_name":"74FpqbrVGbroXFzevznO7","i_price":68.81,"i_data":"nxwpplRw90BxlED0AGUQzW8R3c7iG59XRDWzjOBCODfScULMrJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":617,"i_im_id":8658,"i_name":"sxaxXe26hFT1Ibb","i_price":24.83,"i_data":"XBFRwMUXdEcAbs9Q9WVHUSSYRLvY7iLr0DnhH4H"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":618,"i_im_id":8766,"i_name":"2g52LR3zMP2i1mPaZ3g","i_price":52.52,"i_data":"ynHqtk42DozquRknLD8WMrQMZ7TbkbLi8rvyBrbOb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":619,"i_im_id":8353,"i_name":"BdzUqfkACxCh3X7ZmXhpB","i_price":52.71,"i_data":"vTD7JMtLWid519bt4DOuOb2sB1gm5EEI5JHo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":620,"i_im_id":5869,"i_name":"RtBTDYJ1M3wvZ7","i_price":97.08,"i_data":"WTZ836QCLf6s9xczx3ZlMogCA5EftrLxUI8S6d8MASe5kZJUGB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":621,"i_im_id":2567,"i_name":"5Fk6SvdQ5aZlqAs1z5gEv","i_price":99.59,"i_data":"y279hpOyHq4eCkXxIQhMCAkYgZsfQqweVQWekaKTqvP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":622,"i_im_id":4522,"i_name":"ClfAiKgpzjXO3alYdzfk","i_price":24.89,"i_data":"UQK7O5Rl2Ko88ViAjX9WmbFOuUkjxem3tPZ2Atxnk5TFJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":623,"i_im_id":7393,"i_name":"PSmNJYz7MMCjgAaUzyeKumP6","i_price":20.36,"i_data":"B90chCGfpd68DLSRJItQCe2HTeVcLyc7Zsp5N3AP38J"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":624,"i_im_id":1034,"i_name":"Y7RL4OgHy4aRuV2stl","i_price":65.67,"i_data":"PaKOngTc9XTYOMRJNppJw8TZ7CQPj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":625,"i_im_id":1576,"i_name":"sBAie5QHzV5fx82Zq9gzpU","i_price":32.24,"i_data":"OqZevFvcJtP9LcqwUQlkYgoriginalVKnooLS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":626,"i_im_id":2021,"i_name":"J0hyYk9P3uJ83N4U","i_price":25.38,"i_data":"bC9spwtjH16O2PA1QGHk9VGR2JAhLVsh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":627,"i_im_id":8980,"i_name":"7DYyIBiqXj0jWYr","i_price":29.41,"i_data":"DnKo32VgfWLsEVXyJ3R9LJXUs4wz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":628,"i_im_id":9009,"i_name":"OCazep9pWuL9Yzsk54dJin","i_price":89.17,"i_data":"R2IMPvkUa56wUR0bT9siANAwQ4Fx5eu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":629,"i_im_id":4675,"i_name":"wnp6dLsieyRtDQlegF","i_price":34.7,"i_data":"4L73qNJowQS1zM8du1UjoLqhMxh8RYNS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":630,"i_im_id":8787,"i_name":"DjLfQWnpDD9lS9","i_price":20.76,"i_data":"y341mkBMNZhaq6adapuF4iCX4CzSjS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":631,"i_im_id":9895,"i_name":"CflHQWTmYsYAQsaX6by","i_price":94.66,"i_data":"ETQ3RtsK4h1534X8bZUdLf4FvZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":632,"i_im_id":6686,"i_name":"2KYf1Lv3DA4gh3w8b","i_price":60.44,"i_data":"rZsByuZrqrYUIYW9FyYvWLni3hkI3NVFb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":633,"i_im_id":5548,"i_name":"Hi8VoPf1qW0j6mvsMmCgHWAg","i_price":15.23,"i_data":"AP4Y6VLBjPwfkT4XpGTwsVNLBE9m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":634,"i_im_id":2535,"i_name":"Aqd3WDzYIKtvZ0","i_price":78.31,"i_data":"fRvines6jSDjNkz8I6NWHohzrICkBRw5mdPQH8Ya0oru"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":635,"i_im_id":7498,"i_name":"U0VOWotkXSJ2pzsL4","i_price":26.44,"i_data":"cH5TLZUY80qoX3maDvFBWBgCfsvLoQ7PW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":636,"i_im_id":2860,"i_name":"1JQQvRXDuJQWlKiHbN","i_price":41.31,"i_data":"9t8xMnMO8fJYcBf69dSJBftecRlF0Fw7UUxq4YfPJ92owJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":637,"i_im_id":2930,"i_name":"i917yWGCtlUeCQvv2MlfD","i_price":80.38,"i_data":"NXCKHRzvmWFc3Mf6ANoHEp3iAPmHkd3SBkd7IqT1lInv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":638,"i_im_id":8102,"i_name":"diPp5Vu2b3FCDRiZwS","i_price":27.95,"i_data":"uEAxFxc9U70CB1OcShd9ATqlZpItNMGda1nT62LL8kLT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":639,"i_im_id":4854,"i_name":"JOpTjDGvcqn6ce0pQtToPO","i_price":28.92,"i_data":"wyxq1wUfOCtPpnXBiq1Q7rtfe7ALk48lprYve0tgRqraHz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":640,"i_im_id":5237,"i_name":"LV0L9ie1oECNbu44K","i_price":56.05,"i_data":"sYNFvX0bCMeZRWfngra7FBimFyc4HLuPS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":641,"i_im_id":7403,"i_name":"3OJB5qJW1cgqO3JAE","i_price":78.88,"i_data":"JRVu3q2hef19U4BpyxwF0hiq08DfW4Q7eZcb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":642,"i_im_id":6118,"i_name":"tYxPukj0QKMyqE3OgiD","i_price":38.14,"i_data":"cnW5H04K3hixlw1vpWwvNu3qctxhQCZI1hMnwLNj4ETJ7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":643,"i_im_id":4290,"i_name":"5OidY1SPIPIXarfL492190w","i_price":24.19,"i_data":"EWDKxqdovbiUpJfMIiEG4O3EBSz6EDAoOOmvMhEF3NxI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":644,"i_im_id":9629,"i_name":"YaXjagdzO77uUVAoN8Ozs","i_price":38.07,"i_data":"bNm6uiTRJ5MJJsh4ldjTTIJtWKBouEHzgvXI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":645,"i_im_id":2599,"i_name":"f1YL4SteqKeAgU1CefuURhF","i_price":96.93,"i_data":"9trwnGrPwj6wNEa50jCikBbZyu0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":646,"i_im_id":2096,"i_name":"Mvw5mfPdCuJoj3GImkgN0O","i_price":30.91,"i_data":"bGDeJd4c609LtnM1yXEXvLAF51EBAEgyipwDykMT8ZWMkQxP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":647,"i_im_id":711,"i_name":"r0nHYC6SwliA90MXDX","i_price":30.08,"i_data":"JRcAhoeAjJU9Wol0pisWeZqWniUo7v0Lwph"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":648,"i_im_id":4808,"i_name":"dOU9tRM7rifaGvJg","i_price":18.46,"i_data":"tNW8Qtz830EgYxooDYoXjrA75o8iYpSa53WkYD4Nh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739199,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":649,"i_im_id":6686,"i_name":"BEMkU6IJOUUmRL11VA","i_price":39.62,"i_data":"JKElkkLou0Lp7F5N1Ad11P1yUfz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":650,"i_im_id":3322,"i_name":"atEN6joI3hy6HjfHz0","i_price":73.18,"i_data":"rqd7EHUTncw5dfMB7OsbfVonkUj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":651,"i_im_id":2818,"i_name":"beUihKBvtpQwClc7P2L","i_price":17.65,"i_data":"hoTlFdEyDpncq6Gn4NzsQrrtCbPNxitJ2HJ0A5zl5vIb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":652,"i_im_id":4788,"i_name":"PMIqODa6qLNOD5KOI","i_price":43.68,"i_data":"oYu3AANYTIJKuZSrAoQOx0ZPOk7w4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":653,"i_im_id":5745,"i_name":"VjYMWDzBXY4EjDCe0X8LHTQ","i_price":32.25,"i_data":"mbhmMp6ojJsuCZpJ61hUbhUNWmry8vib"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":654,"i_im_id":9196,"i_name":"4TlC0HDgZEAGsuZ8fq","i_price":99.79,"i_data":"oVwZbdZmm8a6AeKmWoriginalREsuZMMFrElOuwDb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":655,"i_im_id":4960,"i_name":"2qkTLJ62rHd63evB69up","i_price":24.31,"i_data":"Bvxv20Cu2HB1pvB1AkgseccDwm2JoMMI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":656,"i_im_id":4448,"i_name":"IHBjAevGAWi9NH","i_price":71.42,"i_data":"BynXuWkGJ1uyipW6mzVVn4ZCqbUIz5snH98dBpLZrwOh1h6yso"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":657,"i_im_id":5724,"i_name":"e9KDWFtPmHwMoCp56S","i_price":50.04,"i_data":"7PsU7yjJPvtQoriginalz4Pk3JCkX5NrQECtapgQ6FDi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":658,"i_im_id":7718,"i_name":"tap9jqTTMyXCU3xh9","i_price":17.67,"i_data":"xG9ier3KQk5a7V9E3rnQ0hLMbYPOQO8EpZuBwgtOgt31f9qu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":659,"i_im_id":4348,"i_name":"ZnpzeNsyeJXAFZRdDagu","i_price":81.42,"i_data":"P5YfRAaEodohMdX3GPpGBH35QbUFRHVnpjrkHaXVQYIRHiZY3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":660,"i_im_id":483,"i_name":"EiTDCyafUZfWDFXQMRW0bED","i_price":44.1,"i_data":"8DYgDuDiIAXmNHF9OHORVROUPxm6q3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":661,"i_im_id":606,"i_name":"s3k9YdBgCZChqqc2KJs0Rd","i_price":66.93,"i_data":"02oekMOFmmcXbHMmToBVl0O3KhkdlOROOejP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":662,"i_im_id":8367,"i_name":"KTkMaURJWWTFoxQHxo","i_price":71.11,"i_data":"NFZZhhvBkj8lcpCk3I1NT2ox4t2xtmIeg2alBk3fSrp5xy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":663,"i_im_id":9489,"i_name":"MA9cCxBUNSNS7vLD3","i_price":93.05,"i_data":"AYW4RghNKDWVbMoNertgpgQZAD7hZCWaA82CK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":664,"i_im_id":9957,"i_name":"IKPIUJW9FaErxlMB3pL2m","i_price":57.77,"i_data":"9atsEvgNA7jcoriginalM7JF9SRB20HRi7VMT7wAi3pEL5vSs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":665,"i_im_id":6922,"i_name":"QihIjz62Zu66Wu","i_price":25.95,"i_data":"puuyenEyZ4nqLyP6EpVYgcXjTRH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":666,"i_im_id":8148,"i_name":"rrSnOo3FgAlq8mo","i_price":7.49,"i_data":"h7xSMnF4GDRcLFKNfuOuMBPzfH5oklD5c2k8fVCKSN5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":667,"i_im_id":8939,"i_name":"QzUJlNEyR3fVgEX","i_price":67.44,"i_data":"9viBI2cTGH4h7DEBqtoLuxEcnByugZM1iuRbv30IioKNBpob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":668,"i_im_id":1265,"i_name":"RHsx70BA6w1pNyKM4G9Un6a","i_price":47.84,"i_data":"6KK6WSNf37ZGL8LJYgForiginalG4uYTfK7qktYEAJ7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":669,"i_im_id":4609,"i_name":"CZuzywAYPka3z1vwBznlBEU","i_price":52.65,"i_data":"zJqRmWCH9o3S8QJBCcfIxgQgkY3RrORPpxBZ3HJMg3Y7F"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":670,"i_im_id":916,"i_name":"ViUrMTJzbyMv5FEVZ4L2U","i_price":53.13,"i_data":"2CuWuSigwo3NGKjknEOYeTlUb36UeGikGWOWvLyac65Oeb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":671,"i_im_id":2484,"i_name":"ZoX5p0L1uKfHlS5zcCBIj","i_price":49.0,"i_data":"5eOJXG8G42Fm6IjpivGIytRL8OkB8cvvYyZIioYGQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":672,"i_im_id":9182,"i_name":"PMCzdqCNhX7NXHrWGDd","i_price":55.65,"i_data":"qWtaE1A630bQQdcvUXikBGiMQuvbCMlpgGIM7MnOuHSAvnaEv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":673,"i_im_id":5671,"i_name":"8OvqF2FrBbTL7mNeF2","i_price":18.93,"i_data":"ALHocJg5wfqiNNXSzGQNQouQDI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":674,"i_im_id":4132,"i_name":"jjarCgSAbAT6rG","i_price":5.81,"i_data":"MhYXxkAWKG8qCWRC2svt9JQMkVwY9LRH44Zwl9MWFUhgRTQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":675,"i_im_id":5921,"i_name":"az7p1Ca7EXYyYqweozRXs","i_price":71.25,"i_data":"hHhwP5F4E9CVZA6ojEuohWQxJe8LQEJMzlg3nokio"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":676,"i_im_id":779,"i_name":"VBbXpGZXGPu6RCbYACxMRLw","i_price":83.92,"i_data":"nNmsy71NcKU94jWenRDZadSwStO8AB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":677,"i_im_id":8242,"i_name":"mDvI5pU9im2ZfE","i_price":33.71,"i_data":"Hm8rdERl6Oq5u1JuuBsUCCCgov5QQdB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":678,"i_im_id":2128,"i_name":"aujyOBelqlItTXnygq","i_price":13.88,"i_data":"tZkwFASbEQadP8Yu1TCV7JE2VSrCPP1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":679,"i_im_id":7899,"i_name":"TGBV9N8TbblmdhnXWCasQp","i_price":97.96,"i_data":"uLI3WrNWT5ov3Md1X0LQzxiVHgnlL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":680,"i_im_id":6138,"i_name":"h0pWROTb8ipNNPDQLi2051k","i_price":23.92,"i_data":"AEEHw2PSjY9gBM4PWEArNmR57jOYwMVliKCXIMiF4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":681,"i_im_id":4981,"i_name":"YVMIpkAZkAuwhenXwqvzJ","i_price":17.21,"i_data":"xdlvYAUaqy4W0lBh3eIHa8dmMUOZNtopln6TpCaofv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":682,"i_im_id":440,"i_name":"cUNUne059wJJBjNc","i_price":13.41,"i_data":"rCnpcI5lcyYK8fgBp0NnJCZTk9U0Ej34R8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":683,"i_im_id":4510,"i_name":"tmf6ThzUduSQkMuu","i_price":30.97,"i_data":"N7xAaKztPOXSgoriginalGMkvd3T1szjXYB6x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":684,"i_im_id":7259,"i_name":"2vpHzFDpCgoPWSVzT40pPG5","i_price":18.12,"i_data":"vnp6apMh2w8yUdgNTjszH3DBjJg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":685,"i_im_id":1327,"i_name":"cGG3cq9x36uAwKS","i_price":8.49,"i_data":"bL9LKKinHLZndTzz8H7E9XHRn3Grv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":686,"i_im_id":1938,"i_name":"ttBaqvlboRG9ha","i_price":99.47,"i_data":"dlvucqKOHN9LHyYNW3SistbvLZk4rORaM3bwP9F"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":687,"i_im_id":5234,"i_name":"W2i1VIGm9riDFf","i_price":80.31,"i_data":"kkOWfxudq8WEWDV1MkCpnXAr5fblmUqOvb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":688,"i_im_id":5790,"i_name":"9lfMdCdBGwqbEtnU","i_price":81.56,"i_data":"jwqlLeHFdwdhvS338OmGYy9mQCn6lBkb3Ko"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":689,"i_im_id":9590,"i_name":"zpokwAZYw1YQkw2","i_price":55.16,"i_data":"VvOnHcDzvjJEXxYRWvvBEV5R2iqguIfwDYADSuy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":690,"i_im_id":4795,"i_name":"8gl6ruVJi4Sqsqtkg6SE","i_price":11.11,"i_data":"dZ69X2A4PYdioriginalEOFHc01ElEb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":691,"i_im_id":1589,"i_name":"xjuf1THNUvBJ626XGBc1","i_price":92.39,"i_data":"Sg8ncdVgnKrrrxOhJiuyqcEcHF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":692,"i_im_id":5010,"i_name":"llrP3gT00Y8KDEau68e","i_price":46.28,"i_data":"4wNL6T67QkrrNQDgyx0eaGuBWCQ0aeFpV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":693,"i_im_id":10000,"i_name":"DITSpIICX8xjnobtqfX9","i_price":15.74,"i_data":"MQqWmKBJNoP61Ikoriginal4yfVmf4wOO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":694,"i_im_id":1271,"i_name":"jj6X0MHR2poXJN","i_price":60.38,"i_data":"LuKxZaCeZprSwGxtKiitYhrUVgqhrXFxhqaeqP8tceOAb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":695,"i_im_id":6135,"i_name":"TAXWVFRQdqpOGlDSPN","i_price":59.75,"i_data":"aLoRZfgaV38xVSiBoNceqmXybTP1Vh6VXK9304"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":696,"i_im_id":2603,"i_name":"MVkL1oR9l5LRSSp1cHV9Hq","i_price":81.43,"i_data":"zRWcksIB1S9t0v3paCVL4qEKQwY9mKrBZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":697,"i_im_id":2073,"i_name":"Gv73AOi3n6w811eomSRj","i_price":65.81,"i_data":"wRXLJBe6aMxssdOtf5xxZYOMyDkPDzIUb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":698,"i_im_id":4142,"i_name":"mJAy4lJtNLmBVvMu","i_price":14.12,"i_data":"tR3yIgioGl0Ycy2Cz7cPQyvgY025ymgJsdTW5dRVD6i0nWK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":699,"i_im_id":7843,"i_name":"fTaRsKFYtUbCuDWp0YAMp","i_price":94.78,"i_data":"ESEoriginalRbWOFQyL13zVqXQA5RrZJQ723Uql6Pt1fi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":700,"i_im_id":1359,"i_name":"xetPAvJWrG2DGibcgI","i_price":29.69,"i_data":"IBH1xpRHBJ9BtF39057bDVo01z3HdloIkfuBxsTziIaLckb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":701,"i_im_id":8729,"i_name":"D4E3tGkTmMFFURPzZWpDT","i_price":43.95,"i_data":"bbdhkC6lhOwBz5okoriginal5Fa8KaeGDnXV8TFPtpVp24Apnu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":702,"i_im_id":148,"i_name":"07jjDag1YcdxlZP154kSU","i_price":26.65,"i_data":"PyxstrUsgrug6Z1IJP2k6h6pkzbLF7JymDb6xYOXkn9I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":703,"i_im_id":6483,"i_name":"a1YFKlWCHRPoz9IL6Luloa","i_price":4.62,"i_data":"EmeMpfPi4Zagv9f2GVcRLC3DqLi2ukVtyBoiUYCgwT1Q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":704,"i_im_id":633,"i_name":"7a15QhItetfTZMw","i_price":12.29,"i_data":"lrEpE16NHIFRW1R17gLqVlGmfd7M0tr8r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":705,"i_im_id":6919,"i_name":"DSxzmVDcRH9gsXRjO","i_price":6.24,"i_data":"VSh89gYiabMTDy7bkzwHoNCAyMUI36y6s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":706,"i_im_id":6442,"i_name":"7Vi8cLVDUeypkptmG9en","i_price":80.17,"i_data":"gLVKWmWobijKEPkzn8xrQzpLxRRGnO8m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":707,"i_im_id":2608,"i_name":"90QBpHSk4UAB49uUn","i_price":66.62,"i_data":"McNyyO5B70XwlpvK5fqVF3HltePGBaQs00VMGU38Q4mJOdKb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":708,"i_im_id":6462,"i_name":"SLhYnLUjIPKFhp5N1BZysTvu","i_price":79.08,"i_data":"UhPPU8iPGN51n2UT7r4vXYmE2qdo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":709,"i_im_id":6703,"i_name":"CzxoxkRQwJ0TcU3","i_price":24.74,"i_data":"eIZQDK8iNDWMKXdvTqP8j0QYer8KL5n"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":710,"i_im_id":8554,"i_name":"VFH6AH7wwjkCWZ","i_price":35.34,"i_data":"OrTiahrQ6PVKPd01OtD7QBAHTKVLBHb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":711,"i_im_id":8961,"i_name":"c8K63odATjtt15wQGJmOgcg","i_price":76.82,"i_data":"zYojeQzHb2KM5kNyXoSiyeYphxtZP7mHV4fdjuX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":712,"i_im_id":733,"i_name":"DFdHiGsuSimk9tRbD7","i_price":9.1,"i_data":"Ln0kIUZiqTD8a5HJ5LmjFtPfWxXivqRdbFU3m2gwU2tzqT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":713,"i_im_id":4921,"i_name":"hlY6G6OkrQlKpUKvx","i_price":50.98,"i_data":"MdivsFBz4fP31R1CBy50lETHqtPFq4ew5ILcXPBdb7Ek"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":714,"i_im_id":4400,"i_name":"nv01rF8xhf5mmD","i_price":48.18,"i_data":"tVeLCpfcLklF0mu6iFBSn6tD3gAgb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":715,"i_im_id":2682,"i_name":"qZhtNICPmT3xbeKdk8K1V0P","i_price":95.43,"i_data":"7nRES48zTitBLrBawKXxgWjO9r25NZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":716,"i_im_id":9437,"i_name":"3myNTLT01RQpDKcrE","i_price":75.33,"i_data":"aMS5b1pLmGuw2obH1vDXbEl4Q785X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":717,"i_im_id":8337,"i_name":"AQou1VPfElDotJ1iO0fMBe","i_price":94.58,"i_data":"FawnZWJmG58PYbAOXd1uJsX2pjn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":718,"i_im_id":5009,"i_name":"8T3lJaTvZHY2vA","i_price":2.48,"i_data":"A1WDVhgAGU9P4Xrj9HIPP0TEU2rNujKxpNSb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":719,"i_im_id":4494,"i_name":"1KmIXNGL5R9gMJKNYopWl3","i_price":3.92,"i_data":"wFb42I75MMreQhaGDpt8UX9Y3SGSDjAOoH3ViXmz2v2mAi2P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":720,"i_im_id":3327,"i_name":"2NljUxzNts1xtOMFaLCk8c4","i_price":30.03,"i_data":"1LWCScyoriginal3rVDgt5DimyuSlHU5XPYHCjn8yWK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":721,"i_im_id":5629,"i_name":"2GXn7LpECQQDGi4v1wEr","i_price":2.19,"i_data":"2VPaxQKg51qBOYxpKdTw9DKn38cz4oLiBPjSw6dES0Fwo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":722,"i_im_id":7989,"i_name":"w6WqmNGIeptTLbBpEUW0","i_price":1.43,"i_data":"2tZwIHawBchv0Y5bStS0w4gYjuOKeY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":723,"i_im_id":3008,"i_name":"Of5BpUWy82CL4oeF4V","i_price":54.55,"i_data":"9wThRXvoriginaltUD8tFzb0c2LR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":724,"i_im_id":9509,"i_name":"D0b2m9ci32rRDbsYAx2OVatq","i_price":38.02,"i_data":"QMi4Hs74GFoeufXsMG1a1RC19LZNCbC5u2HFW9FcFNXb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":725,"i_im_id":8953,"i_name":"BG1QTcketZjbqnon","i_price":54.5,"i_data":"1O5NWZJtDpX94RZNGpGJDF5wsNg1lK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":726,"i_im_id":2897,"i_name":"nYk2NTiKilobkNAjz","i_price":73.55,"i_data":"k5dZ69Zlzy3C2Iqrl6q7ySGdghwf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":727,"i_im_id":5427,"i_name":"dSWBiSQt1mKuS1Pm","i_price":89.13,"i_data":"99HyT7P6gtwUAA1Z08hm6CmHefOZMpqfZvrrnXI0MIrTPsm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":728,"i_im_id":5811,"i_name":"xgZtZKhbcoWThEw5wGB","i_price":24.88,"i_data":"RbE3IqZO1K6UhA8WJgaVKxqwMzNJQoriginaldzYb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":729,"i_im_id":2755,"i_name":"jZxO1FOI7BYiT1Z","i_price":8.95,"i_data":"kn9eWL5xWiZq4plCTDD4Esm4gvY4Mx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":730,"i_im_id":1016,"i_name":"qf1oZdzGr2W42i70kaNuk38","i_price":76.81,"i_data":"00ybAkucjDzAtIUnjn9lf00KGjpZ4ugoonZJ26APmy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":731,"i_im_id":2765,"i_name":"87uzzaHkdMSx6js1m0fY","i_price":89.63,"i_data":"Odb2dcyOaJiEC36MFR1dUrQtEanBhGL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":732,"i_im_id":6968,"i_name":"v06hJC8wDms84e","i_price":35.55,"i_data":"ZKoxRT3DXPL625JqPeXLtYonFsx2B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":733,"i_im_id":1544,"i_name":"lnQmPf82CqN3qRTELyV","i_price":34.08,"i_data":"znfiDpEYR9ScBm8sg8LPdvLlRofp8kb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739200,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":734,"i_im_id":9706,"i_name":"GS100o0r4lRObBILN","i_price":36.24,"i_data":"2KWcNQFNt4FODfBw7BO98ejP3HZX6tx44tjVtb5fDo6Rz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":735,"i_im_id":3946,"i_name":"Pvxw7Ts6nCrP4TSp","i_price":82.75,"i_data":"g7lagbKXaKmehSG6KKr9CkhafjswcCEK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":736,"i_im_id":5306,"i_name":"TW1LYUcQS2Dru5mp","i_price":53.37,"i_data":"lQJZQzibD8qNitgdlj0nRocQQAxVnhlztZpmbsH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":737,"i_im_id":993,"i_name":"dUGDERmG8Vrnzj1CRQzcYU","i_price":59.64,"i_data":"hfv36ZGhPEFNeXRVclnKHt8UqnVzPnyCczTTs2Wx3lR1k9f2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":738,"i_im_id":1094,"i_name":"umbDYpJJUBxZIFOghDdmK6qu","i_price":25.13,"i_data":"HlR1HlHQOpF62EcYvFRFcNCdldfenj5Vc0y9Q2dxMxt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":739,"i_im_id":5843,"i_name":"IzbpCXtzU8qKLX2Qnz2jhuf","i_price":50.09,"i_data":"2MA5UkWYGQT6uH1eAV4KTE7TKqdoriginal0T7rdoWN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":740,"i_im_id":5017,"i_name":"8GA7wxUD6GFT48LLT","i_price":35.7,"i_data":"axn4CMK4Zi99Hztqk512kT7KZkgohlaJoHpxv0u"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":741,"i_im_id":6718,"i_name":"zBm65MU6sxXieUOllu","i_price":86.21,"i_data":"WZNMGYOoMwi7vqENo0vxzZ4Ktg9ujmvoriginal"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":742,"i_im_id":2903,"i_name":"v6WfOyQkIW49I8w6g","i_price":63.82,"i_data":"vdS3nLMpHzEwBwur37Sh4NK8DTlDGZAeutDIb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":743,"i_im_id":8402,"i_name":"83bOSm7TfAD9OAv7Fw","i_price":27.48,"i_data":"CdUKJjpsrdLaJRKQ6pAmoKbrWSL79Ya3gpHnFVjLA42l6p0vRr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":744,"i_im_id":3815,"i_name":"yBsTxoMOSuL2OQ6KMEPM6cLK","i_price":6.22,"i_data":"TyTL2GexsaBFmoriginalLKGZM8LeIgg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":745,"i_im_id":2545,"i_name":"vPlb1hBQU3px76vWSEm","i_price":56.89,"i_data":"mHvM7DqaIFaDzeeXMpoccKwFRBN6wtJWppkuNfqnoG88oxx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":746,"i_im_id":2676,"i_name":"4xLfR2LtElmCG18gGG","i_price":87.54,"i_data":"6lKcuISHe8VIH3KsVkUOnQ9TASRTRBry"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":747,"i_im_id":8790,"i_name":"PNkk03cra6W80jV6oDXizVgX","i_price":35.89,"i_data":"LRmbo3IuPEM211dL8kfA6jbzPxCamy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":748,"i_im_id":1482,"i_name":"ScgBv0aPRCffHo","i_price":63.59,"i_data":"jgsBEjbuCuZoVmy121PvmQMcyjtp6un8IExi13Kk20ybySMRY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":749,"i_im_id":2846,"i_name":"tHM2V9ymycZdRs6ZPcG3g","i_price":36.22,"i_data":"u489N4fNkYeREUqV3zLjq87N00yPyzRxxQc5Lo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":750,"i_im_id":6515,"i_name":"fOGulO7lbAJ3li30yYtadX","i_price":49.56,"i_data":"aZU5vx3lcy5xJtJc4Sg8ukGzTK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":751,"i_im_id":6974,"i_name":"6PX4rFXrE9DHKZNQoRrzz","i_price":36.12,"i_data":"YEGdcJbynR2AJBqoNzy8jM9318I7KfSNBpTXEFvQTSWFQ5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":752,"i_im_id":2168,"i_name":"sJtOMpYW0fbPeLltexDrvLh","i_price":44.57,"i_data":"TJrJ16moriginal8kuj8zDPilFPBsdnjzKFFFO28x9N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":753,"i_im_id":1378,"i_name":"zg8ggpg3qkR0RmfHa","i_price":9.34,"i_data":"kg6h1P8nGUCVrdaIjEpBqw2pkAjf7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":754,"i_im_id":7510,"i_name":"aaiFxWjUtXKRBumYmSqlgYRb","i_price":68.36,"i_data":"Vy0zLexKtZZG4GIwCOUXJ8cfCHtH2S6jrB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":755,"i_im_id":4264,"i_name":"2CmGCNYlnla9x0hYE6nkz17T","i_price":54.05,"i_data":"Ge0dNn5oYhL6A8i9boriginal8xdIeIG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":756,"i_im_id":6572,"i_name":"aa5hqRRvupUCDu9NCBsP6zZ","i_price":39.52,"i_data":"vB9AW9eT62LmqV3GHAEGZOiUkdzbQduw7woFHGeEXuJBSOQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":757,"i_im_id":4855,"i_name":"qmMUUOHzOp6AxWvSI7tkK","i_price":57.34,"i_data":"XayudUvyk5Dy3gE2g9DWRIXdlQaTuFik"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":758,"i_im_id":9361,"i_name":"o6NQbq6fMGQZbsvY","i_price":32.83,"i_data":"kJqyP5ksdb9MVWZ3pW2ssdoYU0KNWevkkkTNWKR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":759,"i_im_id":3725,"i_name":"Xb8Uqy3Vgr2jX2XtzBC","i_price":70.1,"i_data":"WMrkFBtAnaequtufEdEkojGBmbCoLhLzq3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":760,"i_im_id":7504,"i_name":"r85iRmJo8q4g35Je","i_price":43.88,"i_data":"eFGiisJpDnWZS0QjsjgdE6ntQIyyKjucsHTNpqclSN01"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":761,"i_im_id":3624,"i_name":"ND6Qj0uJo7PNghLG","i_price":80.56,"i_data":"AIgzfWCVQZYagUCDTk6WD2ctFmSU8ov511ql4b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":762,"i_im_id":131,"i_name":"Dffzyrp2r3cmvEkyT7kH","i_price":92.56,"i_data":"g25ovKHgKIIfHVsjJXGD1KV5hcsW7s0lfOIWj2Zmxb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":763,"i_im_id":8283,"i_name":"RUXEoEj2aQt1BCKFNSZt","i_price":13.29,"i_data":"s2lG2EiONKbR1q6mAAZjac3LirysALwbRxufks"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":764,"i_im_id":6228,"i_name":"Ppbe1YE5u8tDy5JwDIhkDnYq","i_price":27.39,"i_data":"ZQIRJmwowMIJS4WQ0gHmVYD4AjhntJMu7CR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":765,"i_im_id":5344,"i_name":"7tYij9P4iJTc8bQbMNmAZt","i_price":8.94,"i_data":"F0JHKaWcnd1glBzUZtb6iILJbmH2z0Pch0IdeVGMuG3DxHTl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":766,"i_im_id":194,"i_name":"RoefUWwzCtzEHFVoQe","i_price":15.25,"i_data":"1Y6BPLLeSGv19n3xSKXU3MfsoTR9aqEg1YwNpyA4efc6sSYw3v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":767,"i_im_id":8664,"i_name":"bi2SGgPy13Wo8NDq","i_price":83.74,"i_data":"shKk0k2rpnfcYCuOvroriginalBBlL6b9potkT5qNCb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":768,"i_im_id":3808,"i_name":"VjEGHq4Hfr4mpdH","i_price":53.19,"i_data":"AYpBKADDWpU2HAIJBBK89QlYRMTjljMS78BpxPdAQNft3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":769,"i_im_id":5680,"i_name":"DtCEabdrzm1tJabBp","i_price":14.77,"i_data":"sozVFenerrI37wT2eIS7AXv0d6hFto3S0EG4v8suvlUw1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":770,"i_im_id":3296,"i_name":"NW1fTAdEz1BlUxLah2","i_price":86.7,"i_data":"WOVTv6iWh0xUjXTDxFBuynVkuy48XQjmL23t6MpZYjpbV0xIg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":771,"i_im_id":7662,"i_name":"YbKWuFJL6pMMKh5lkwXhC","i_price":19.11,"i_data":"OTOMS9lI0MPPpJ1IUbIw5i7wXeNtr5aQbSQLWSpcs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":772,"i_im_id":9001,"i_name":"Lo29dO7aXKBXyIS8GZSY","i_price":14.33,"i_data":"fpPPgmfmDFnd9ahJLRmuw0rxW7gKRB1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":773,"i_im_id":6854,"i_name":"4GswP9lVt14oUlP2upG2q","i_price":45.11,"i_data":"0LvW5VKNhmtyYAam4eZhywpoJz6Vq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":774,"i_im_id":468,"i_name":"yztTo8pZgplkub6M","i_price":37.86,"i_data":"Na9A00dxyqZcP7YoriginalGZnn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":775,"i_im_id":4724,"i_name":"eZ3cV55kkZSlskmKrHekl7Z1","i_price":25.98,"i_data":"MYU1IziIVlKXtxnMuALst10yrDOE2p"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":776,"i_im_id":8913,"i_name":"VJdxOa0cUOCdehC","i_price":76.0,"i_data":"CdiSDZOukewoFNA7T3UEUYAfvxXnkf160uibsIu1I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":777,"i_im_id":2684,"i_name":"dP9WhVsOtSgHeSc7","i_price":92.04,"i_data":"qvofWCPfnE2Fv408sRmD6GgKHeIuNDkaAS7rax41j"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":778,"i_im_id":806,"i_name":"7q1VcxgtxOax0uihVP4","i_price":33.83,"i_data":"eE6JR2cyNEkCi0snvrJC8fG907mMpQn8mybodV9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":779,"i_im_id":9996,"i_name":"OaP8iZXC1pp1aFJm5s","i_price":29.02,"i_data":"FgyV58OS9KWH17hVrVXmlIURvGtANp9adcuwb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":780,"i_im_id":171,"i_name":"5Thm5C86Ujyk1xaYBiH1Z","i_price":53.87,"i_data":"zol1SyrTS10cebsZ8JTvDZoczmhff8EaAtvpJzqkMa8jFPtBnh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":781,"i_im_id":9521,"i_name":"gUKV6ROlCtV9GNPkM3w","i_price":7.23,"i_data":"0FUysdouf7kJ7J9V3jL99ZFwKME9Ngvxm9CwT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":782,"i_im_id":2665,"i_name":"wnLYCRGWqEd0CYuUQugaJJb","i_price":83.91,"i_data":"qsRgKkoHIB5a3tvROTxdJ7ldfJ8BSys3mvxAYib"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":783,"i_im_id":1294,"i_name":"RFpiCoSHuttttFnw4yd","i_price":8.07,"i_data":"OZezIl2J0evcLE871original6LfRNKzLOW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":784,"i_im_id":696,"i_name":"D86Hpl2U2PU0aRjbB2zy","i_price":2.71,"i_data":"896un3fiYHpWPyTbQ91BtCoLgbY4iw6o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":785,"i_im_id":6532,"i_name":"Puxk5YIOcdh6tHvlaJ0gy","i_price":12.66,"i_data":"WBVMOD0iKlAYAMCWGpBOqLjlnZmdlUUoriginaln1COPWOgb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":786,"i_im_id":2868,"i_name":"zOGsAMgiUpRD1lCUb34ATM","i_price":7.53,"i_data":"dnJFe6XHtiIyiWn2Pf0bVqtpkcBz4MeCGtv7oMNMeuV3lYb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":787,"i_im_id":5979,"i_name":"zROImS2r0gmZPHu2","i_price":70.08,"i_data":"C2Um6DNQzqSEQNx9shumtWfZp1kPWSdwlhL7NriawKpEKsb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":788,"i_im_id":9354,"i_name":"ug6RR5mud2770w","i_price":37.59,"i_data":"jBSLy3kBCNpcJzrGjLcIhPpRZsT5RMnYuygQOKATZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":789,"i_im_id":7663,"i_name":"N4clAb9geQtpCyqoL","i_price":54.62,"i_data":"XCuwbn8tgHRcbcYzMcqm276hHdef35gcYr7bmr9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":790,"i_im_id":7531,"i_name":"XfyfNBWIKmqgwRceqge8zeXa","i_price":24.63,"i_data":"ODKy8x36EHMxc2WlvJtjQpp2wCY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":791,"i_im_id":1060,"i_name":"fAZGgCJ3Fz2EaHd","i_price":32.82,"i_data":"WnRWL2p1UraKSmJfPs9zXXiiV3AdSo6zB7mo3b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":792,"i_im_id":8785,"i_name":"GpK5sURU3bDLrEjU","i_price":4.61,"i_data":"G0wHElPftcHhGvf5v7TgMhwa2t3LsOmc8LZFaw23oS2LQL3R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":793,"i_im_id":5088,"i_name":"lX3Ycw3Z6b65pLNM","i_price":20.37,"i_data":"VxVBB6WVDhTxhsFre2WTuh36jqmuZBCgVGeIDm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":794,"i_im_id":2548,"i_name":"y0ztVqQkc9RISpY","i_price":51.97,"i_data":"uefnywZDiSFHT1NsFSiZSPUZa7b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":795,"i_im_id":2314,"i_name":"k0qAn8ErQcbdaAsB","i_price":91.81,"i_data":"kzWia3KaohHWDlLJpjmM5HVpeBW7BGnQlx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":796,"i_im_id":5445,"i_name":"XM3GerTLovpOmIsjXqcyu","i_price":35.99,"i_data":"kskTFgHUn0lIs34ZkuZz1fEt9d4KinQiU1cVvNcHuBgv4bb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":797,"i_im_id":6163,"i_name":"yCwguRlWVZMAIfHgUmaVt","i_price":67.13,"i_data":"cyzSwx4WFMoriginalLdYmaZYHXqjqNjdnmLPwtNBvPi6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":798,"i_im_id":4541,"i_name":"NQ1bCYV8lzlBuI3kxijPdZl","i_price":14.81,"i_data":"jAO7Vj07IgEeidNT5pd7MpSZhdjRhUHBaynb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":799,"i_im_id":5941,"i_name":"0vxugnQUNvBdJzgcDrz2e","i_price":1.12,"i_data":"1bWUJokAWOvSfd2fOHYJlQEJXubt6v7T1q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":800,"i_im_id":1413,"i_name":"UQb4kGlQBaQuZjEgW4fdS","i_price":50.61,"i_data":"S6NcxzCdlCG3bPu31T1w5yYFulV0sOuAXKKD8w9RbyRXDl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":801,"i_im_id":2309,"i_name":"xmRyNN5aCowYqCef","i_price":96.55,"i_data":"7NCDtDbyHlT3Wx92UsInoJX2dZeRhMXh99zO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":802,"i_im_id":5746,"i_name":"LcZRYcEeaHZrtZ6dsCZSd","i_price":46.88,"i_data":"lRszJs5JeVZBHo0NIw8VPS1LQC3IidHxsObCT8LEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":803,"i_im_id":4983,"i_name":"oA1rcvMtJMM3WN3IjDTlrI","i_price":3.52,"i_data":"nWqu3Vba4uSEZnAmj9bddlCKGidokJdx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":804,"i_im_id":9505,"i_name":"BA578yFXXEEvny83VQk","i_price":40.41,"i_data":"J20Wo5rawnEhicerp2uXmwRQr91FLRVmjHGwvtH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":805,"i_im_id":5317,"i_name":"4YoLClWCZdrTBAaxp","i_price":72.44,"i_data":"XtPE3yHkD58n0rrazGpJC5MgyZmn63Ku"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":806,"i_im_id":2660,"i_name":"rqBJSV5ieYSGSTg","i_price":11.87,"i_data":"f7faG7QiBqfPyT1TxaGirqCzC6xE1BJowLeaGsJx9vxQi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":807,"i_im_id":4428,"i_name":"XvSxvehW2SpKSb","i_price":90.41,"i_data":"Z5DNHdCKBeKarkC9QlsQEXVzGa4NPrjcxaUs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":808,"i_im_id":377,"i_name":"4JJMcZjZtUSGJ7oR4dE","i_price":87.1,"i_data":"pQH4PprHNOxbGhcvPsKJghJC3msmBvTwUXp9dai6Njxq4vyp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":809,"i_im_id":4374,"i_name":"fZaI8AUqdtHfeyCq","i_price":44.69,"i_data":"P4Hvq0yNMjw0qWs3G5EoJQ3aEkrEuZlXshb3XS5ndZZv88"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":810,"i_im_id":3252,"i_name":"XktieuBbkiTVv0kTwrmRTz","i_price":87.21,"i_data":"aSAqUWzooPl9mV3u2lxPLO3qX2originalUHd1hPW2sWbTVo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":811,"i_im_id":8553,"i_name":"i1beqaWK1HPC00z22t3hLrp","i_price":37.25,"i_data":"c3s198k55oiu6C7qAQQfsQGMjWpPNy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":812,"i_im_id":5977,"i_name":"1UvmDizBLbYocU5Nx2kBh","i_price":70.6,"i_data":"HWRPUHsmjaoWpShtfK9W6fvVoEjiuKHQpeVZ1Y3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":813,"i_im_id":3814,"i_name":"39hfOXhwUigq0UnB4","i_price":90.02,"i_data":"Bp1xJojRpbfnLFLmvpujJ4Asa7ZLdorSfGXTXkLq7Sb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739201,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":814,"i_im_id":26,"i_name":"wiAPnE21zfHA6Z88E20V0","i_price":27.52,"i_data":"Z9tQsiU27d3niPIIyB717W73UxM6DuOFaBP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":815,"i_im_id":2587,"i_name":"WafiD0POjoXJJaHQ1VrXXNo4","i_price":28.19,"i_data":"EAVlRWncjXOAH7p0cwgZ80ZssEg9ZtU2jvVv7hf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":816,"i_im_id":2776,"i_name":"9JjqU3EskbDHNt","i_price":68.79,"i_data":"AVTIzQy0DbG61PCtvLZgsQfrpYmsiYAzb6aoqaOgKs7Em"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":817,"i_im_id":2346,"i_name":"1x4h6cd4oFGerRvftfWiv","i_price":58.09,"i_data":"Wb0hBFW1Nh6pQFWxFKiuUn0fh9zIm53enfgfL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":818,"i_im_id":270,"i_name":"qj3HacO8gluMPy","i_price":90.65,"i_data":"s5V7sKF2pGcNGxBc5JNOufWGxZCBiZWKBb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":819,"i_im_id":3505,"i_name":"RNgNrHBFdqeiuBPae41kphfi","i_price":89.74,"i_data":"f7xWjIZNYpBt3AaZ3c5TTHqUEUD3siX5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":820,"i_im_id":1193,"i_name":"vY72xMdYCe0iMsQi","i_price":62.56,"i_data":"TVoriginalaJW5WhmD7sMxneZ1YUwR0zXrLzXuEiTtydqX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":821,"i_im_id":7524,"i_name":"gUrg1FzLkbooCBE22WIg4","i_price":21.0,"i_data":"SxMalb2k025saUPLMb68BM4xNX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":822,"i_im_id":3727,"i_name":"sukmVIXCSn67vVAlTet","i_price":16.01,"i_data":"p4euVoCUgdfpAaGC7PkwbAjlDTN5IXpa7S1FndycjtI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":823,"i_im_id":6965,"i_name":"wHG4PZVR76vx6uSI","i_price":5.54,"i_data":"jflcbXYRY1vR0IRWZgs4VGn3wO70gR96l5l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":824,"i_im_id":3456,"i_name":"aYHElUwXeTTN4OCtUdt2H0","i_price":13.25,"i_data":"CEfB8uInIkqdoxKxu82Ru7uLjOnDoXW93xqyrYAJ1lkm4b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":825,"i_im_id":6624,"i_name":"l0mzimgwlsXqGUBgM","i_price":85.26,"i_data":"nG0PUqcQup57xa0sY1OMMopoc4Lpr9pnnLpcWn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":826,"i_im_id":6363,"i_name":"rzBXDyD76WdnD8MMINzi","i_price":71.33,"i_data":"rFKK9Alp38GL34oyrIqd3MWwmMsAfz3mmQwU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":827,"i_im_id":5934,"i_name":"bcWm1WTcUUblbCsO","i_price":68.85,"i_data":"QeDWyK7zMmV7h5NQtjTEoqpGDS5B9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":828,"i_im_id":748,"i_name":"hb6al633PbyzEiSluDhy8q","i_price":34.61,"i_data":"aCr3ClfyJ1ONBzQdF0zB5z88QEBJ56k0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":829,"i_im_id":4470,"i_name":"9e0hEfx0B96dXvrJabce","i_price":40.88,"i_data":"9PlhUD2HfM6csudLvCSRHn1lIOY9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":830,"i_im_id":1173,"i_name":"GH3DziNv1WyKzfZyay","i_price":9.96,"i_data":"Ho08wZCsGZ4CmfUW0xOzSi0f5aRap"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":831,"i_im_id":9772,"i_name":"vSbUM9brN3tmHusQBk","i_price":60.58,"i_data":"OQ7JNrT4gMv1rZa3sjMOZoriginalpYGQCHfBPKvxSKlYFLyQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":832,"i_im_id":7757,"i_name":"1R84QZh2NZ8GHnqOUwXR","i_price":37.55,"i_data":"dFaQjipqXByqxAezIzzbz8747VBTb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":833,"i_im_id":2090,"i_name":"pYW2sZ7IEjg78gvea9","i_price":35.97,"i_data":"AwUIZcM8uTMIpyVMFKMVZ4qXkP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":834,"i_im_id":3207,"i_name":"5p2b2Ifwi1ZuIlmWWsP","i_price":99.21,"i_data":"9CnLEws6QVWtZUBJWXrXfJOwBcJWdui9JmQffP6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":835,"i_im_id":6726,"i_name":"YffrvumTPlZqR1kTRSm","i_price":10.91,"i_data":"sdVWjb10QaGhwMrjqgsX1nSvboMe8VDZWk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":836,"i_im_id":1406,"i_name":"YORinqwGkNuvvMcHy9XuE","i_price":3.1,"i_data":"V4NvBBxz4P5XQfutp5Tf709VFaPJqHEuXHesGYrY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":837,"i_im_id":5831,"i_name":"zrfVBd1A6T23x5PhAv","i_price":61.89,"i_data":"pZtZyF1KXNlMjJVDDbm90UBPgfvvYxdQkXVyt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":838,"i_im_id":5817,"i_name":"DZLflGTUx5rk2GFNQz","i_price":1.56,"i_data":"5zOM8rOm3r7SRdoFFjcM9CaMbBxUNwXBvhyIdw9DMy3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":839,"i_im_id":4617,"i_name":"Z7HJoJWePs9DfL","i_price":39.24,"i_data":"wMbg8IqKRp7RXrL9zrEjl2qHLWdR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":840,"i_im_id":6148,"i_name":"w95BTMeuzJYLF27VniD6BgB","i_price":79.11,"i_data":"ZTQr7marcxuoKLvMDVPkTCmmdmJrl4laK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":841,"i_im_id":6333,"i_name":"w4RHlt14C0ES7v","i_price":27.72,"i_data":"qKqtAtOLpGMxuRcuG3cD9vMf5idWsnP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":842,"i_im_id":2187,"i_name":"BuqCgwuEKSLEXJbl7DYRYb1","i_price":69.47,"i_data":"CGMibG1Lv1CXcgZjItqVBmBCQp5xYob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":843,"i_im_id":3366,"i_name":"RKS4ZEeZN5Ugo11lsJJCgQRS","i_price":39.94,"i_data":"0aR1WF519RvxXCIbFTpzrDctPVkhfcYTdyHOf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":844,"i_im_id":4991,"i_name":"nUZAtCgfhJyQOrPha2A7","i_price":96.27,"i_data":"fs4dyRSemM2W0EscxfsGyuPKlXSAvYpTZgokYq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":845,"i_im_id":6020,"i_name":"BFrj8zsR50LywQJX6YRGuI0g","i_price":31.7,"i_data":"ajlGE5OMLUQL7Cjv0VBz8wSEefy2l96w2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":846,"i_im_id":9022,"i_name":"6qjUjtqITDLjOJGJL6vO","i_price":62.29,"i_data":"6d32DFjHE9rswm3VMCO3OjWioPO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":847,"i_im_id":4003,"i_name":"1QzoYSwvyyU6o2SuNll69Be","i_price":58.23,"i_data":"YBiJWASWufnUEQQB6m6mKOzY1EqT70nAOKjJBL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":848,"i_im_id":9311,"i_name":"6Cid5cHWE0Jhvbf3J","i_price":27.68,"i_data":"3erXXHf8GNM9EWixm8VyGbWiQmxERw9yqwb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":849,"i_im_id":2554,"i_name":"pSmu76DfLDpInp9","i_price":53.77,"i_data":"Y3918avBWM1Jj61AM5KSExGfLNo9QM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":850,"i_im_id":5663,"i_name":"NhNfGaKlT91S7wev6lwvW","i_price":81.62,"i_data":"ezUthyxHmndlwOAL44oOCLnRXkP2ofD7lKj2l3TyLVBv5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":851,"i_im_id":2917,"i_name":"XleZC1OP4pKtsqFfyWH09SWZ","i_price":33.88,"i_data":"rAFzYH7gmebTSDIAdlboImJsgczHCgZo7oLNOtfoniL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":852,"i_im_id":8867,"i_name":"fEajBZOY3Q5OI6K99FW","i_price":81.3,"i_data":"kBJ8r48cjoriginalu9PG6edPtBUD0xsQZDQgNK4rqo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":853,"i_im_id":8957,"i_name":"JPFED6ibtPrfXM","i_price":7.92,"i_data":"J2z8pzmYu28ly9LX9I9SqC2nYgefHMIYH9SN4xmjpE1g47bIAn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":854,"i_im_id":3866,"i_name":"HLJJl5jSsxF3o32","i_price":95.36,"i_data":"uqpGeqR1Px4RrDARtIMcpxzF8zn9oW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":855,"i_im_id":4530,"i_name":"CRAc9VAflcz2tFFIZ","i_price":96.43,"i_data":"jkesnsvVmYCDgExMW3QhKVaBlJLFLeI7tIHFwGlLh4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":856,"i_im_id":1923,"i_name":"qepymlgDIndNoEaR","i_price":18.78,"i_data":"QUXQA1QbyxZxYGORqcFxbFfKAOAgb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":857,"i_im_id":9114,"i_name":"HvyuBEjAdjIuZHWqro","i_price":32.16,"i_data":"tCTvU9VQXUX0q27dplXup18kuRkgb7uiWt3FMvakob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":858,"i_im_id":7059,"i_name":"va3JJjZBG5BkyBRl","i_price":1.79,"i_data":"RVonnosUSalgIOYKMeH2bDrOrHIXBFzdb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":859,"i_im_id":8514,"i_name":"JQNBF5MoBQIdn7vKZO","i_price":97.21,"i_data":"K9Ju0qdeF41igKHOu4originalj9LbLsriOt4O8Q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":860,"i_im_id":9919,"i_name":"HnU56EFm3cfhV633K","i_price":65.4,"i_data":"bYUDiW85toI6bRuFLt6wFJ12ZQ0GW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":861,"i_im_id":224,"i_name":"sjPUoLHBbatTmtocHMypO","i_price":99.89,"i_data":"hHZHGxqJg3XGVBuxEQE7JDVYgjf8CzhPhjs2X9dHTP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":862,"i_im_id":7315,"i_name":"vWqesjkTL758RF7KoOnRDKfr","i_price":39.25,"i_data":"Zk5eSxfKMpBz0XFnuDXpwg8Z9vsPZ4kO3spSAKDL9IcSf6Ob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":863,"i_im_id":8564,"i_name":"WidngrZLXel7yzSF73HV9","i_price":40.18,"i_data":"wYglCf4LUasA9lK2gmTg8vlFdcRhxwidNeCSBJoriginalW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":864,"i_im_id":2264,"i_name":"njbqCyHTsu8mcNXPIUEvBS6D","i_price":65.27,"i_data":"9iWkfpHSMYzrbN0RsbzC0nsOwDCkp0jnv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":865,"i_im_id":820,"i_name":"gHvTRO6CFuayHg6NqbiKpKQ","i_price":37.66,"i_data":"l2etxI2gKlvyyWjx6xKuwgAld60xksswc5zgAU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":866,"i_im_id":59,"i_name":"4UwppJQdwghEoZJdakYDO","i_price":46.43,"i_data":"81CTZnKq7ZVER2FpHjnqgNrWFb8zvNNhLcXQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":867,"i_im_id":8423,"i_name":"0F55aN1ZZYELTEU1nGr","i_price":73.52,"i_data":"HGjBJIjEUKl6GuxMtHJKeTM5BCqpIU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":868,"i_im_id":3306,"i_name":"N0qYmHZtAsvfo1q","i_price":19.78,"i_data":"Agy5otYjcY4pNKSjVGVKZMCNAtBwfb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":869,"i_im_id":3936,"i_name":"LxblBQ3wDGor7u","i_price":42.26,"i_data":"sHxtBiy1Wmv03vXTOUBai3CR3waRX4tc55qFfauPUKcU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":870,"i_im_id":1623,"i_name":"URAel0CqfSmFM3ZOpGxu","i_price":30.42,"i_data":"2uhXZWg3dvK0T8jFsnPQEuI0TMfhW44r6XWyexmG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":871,"i_im_id":6855,"i_name":"RsyBqiILwhYlasuYrI8zrBl9","i_price":7.26,"i_data":"WYa74deoubilhVUflkFc3TOYKTpYeiE5Q27e3Sb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":872,"i_im_id":3968,"i_name":"USq6h35HyGJ8XrqWl4cb7","i_price":9.52,"i_data":"5qzLgfGabF4MTiIXK7njqxH37JdKxtIlFFB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":873,"i_im_id":9245,"i_name":"5IsIzgweXipH5z","i_price":50.19,"i_data":"TZ9uZiq96gj1fqxjKzZvHmrTPWiNsYJdTLEk9ZP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":874,"i_im_id":3067,"i_name":"6y1RUqB9hAq13DWU","i_price":65.47,"i_data":"4E1YiaFBylt0EoazChnc3t2WbstaNiLwd9F0qb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":875,"i_im_id":4463,"i_name":"AzB4zjIpYKNQJ0ipKH5Rb2","i_price":40.18,"i_data":"avbKvP4KdK8bP9zcJvZRryzlRnL8AKtZDenV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":876,"i_im_id":7736,"i_name":"QxEgQF0gSaXpf4Y","i_price":87.6,"i_data":"431ikmozcLJytJnzKolZoqHnRXC1QL7ijqhLdcjDAt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":877,"i_im_id":1767,"i_name":"WNDES0MdgiRR8jj","i_price":89.86,"i_data":"AYQXV5bkJIZK6U02tYJdjGCRttBbNb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":878,"i_im_id":26,"i_name":"ErAb56xD8pf555qNassG","i_price":29.92,"i_data":"XhYZTnUrtfxJMlZ81aPxnDRtcquREUcOxMrMrJis3ggDVOuR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":879,"i_im_id":7479,"i_name":"X38PxEKWnWnZjzWA","i_price":45.21,"i_data":"hk23IBSG4tr1Y5Qn7k0ni8AlV0Hx7IBakvgagvjhxB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":880,"i_im_id":6696,"i_name":"gHH6wWJcIFEki8lidH","i_price":16.63,"i_data":"trcQHTIM8hgqHn1YCNPb77RabxqilBCzREgV2cb8pANvI6TTb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":881,"i_im_id":1089,"i_name":"diVJmsHNgwOtPEkd2","i_price":18.17,"i_data":"UHkJhrJ2iBBRlkmNzlZ7XcGKa1cPGJLjWMM8qTlo0GqS5g2uwu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":882,"i_im_id":5809,"i_name":"7y9qcDzViNZNLuG6f23BYi","i_price":3.22,"i_data":"CN4LBhxzum9IT6OPS33SQlC8jYCfaaQDHX7IMbzIjI7N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":883,"i_im_id":3808,"i_name":"4ap5L86I9N4o6CCYvDsk","i_price":43.66,"i_data":"SjTp1ga1NFWeK6CTjXt9A8ftpWvgkifVwB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":884,"i_im_id":2366,"i_name":"hZldgiYJTbp0aoA2Nb1h","i_price":46.95,"i_data":"3JbBv7ZurErZU0Rocd0hAzs6hOb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":885,"i_im_id":4818,"i_name":"rOl1hlxGDZbRZlJfLoHjwM4","i_price":49.15,"i_data":"f9mSiiEWTJZF7XnEMoHAIL48GuOQx5SZubuzolhS1wspuml"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":886,"i_im_id":8541,"i_name":"df9o64ZVbq5kzsWEaaDT8tOi","i_price":45.58,"i_data":"ga4uCYAgiSARH1ZITR1XkALsumZ0JjXwh5YaHT5pMeD2KRvX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":887,"i_im_id":8603,"i_name":"ZLtdlrUys92fuSccJYPmx9","i_price":97.42,"i_data":"BumyWnNVNtz2EtB4B96dJ7MTqU5yz7NQQDpkrfKB0Vzv2Pn7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":888,"i_im_id":3681,"i_name":"K3y8UXXqppTVCIEQ5As8CU","i_price":14.35,"i_data":"OmFm2cfiHuHOgCFKPY8HQVdmucpLt4ffiQot"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":889,"i_im_id":3659,"i_name":"UhIUbDmRt2CkXqx","i_price":67.69,"i_data":"jELgZnt4dBF8v2MT0OJxqQt1cT524"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":890,"i_im_id":6635,"i_name":"t59WezBkpcrvXagU5feH","i_price":10.33,"i_data":"yCYvgYE1Z91FdlwcbYKAqrPnRCFhoBzOU9eVl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":891,"i_im_id":9607,"i_name":"BGJs6d3Aw8Kzoy","i_price":76.38,"i_data":"Y2rkO0kG3Tk8gMWB60YZkZs7rjF7XRNfPEhm5Oc7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":892,"i_im_id":554,"i_name":"zDhfnfp94ZBkpL","i_price":16.66,"i_data":"qbemp43OZO3CKSWZy1AVh0WDcdYS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":893,"i_im_id":2123,"i_name":"IbTttXxw8rgwERXGX","i_price":9.52,"i_data":"ybPlyont96WCIzIRTkmEVOVFqG2zJUCEu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":894,"i_im_id":1510,"i_name":"qjVwvkToI6szzA7DjoYr7","i_price":11.16,"i_data":"originalofdjeKQtHKxxUYtXUaWipygWRRIiYubUwJGVK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":895,"i_im_id":4254,"i_name":"q7ZUoEHOorsjVLz5m9F0ggew","i_price":55.62,"i_data":"f00mzzcLFbEvzEbmbPPlQ8NwKwP6Z0d4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":896,"i_im_id":8713,"i_name":"EyMegzSdt28ykbxFeufsbVL","i_price":91.06,"i_data":"gOwQK3MahPTRKKnXmcP2qcssFoNSaryspgPxQzBu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":897,"i_im_id":7897,"i_name":"nVgbdsee2SP4FB5Hq2TBYep","i_price":79.95,"i_data":"ADLSS4nl4V9NCbnYJovDweAExb9lY52Zhsffx6b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":898,"i_im_id":7127,"i_name":"rKgzFhLYAklXz8S","i_price":77.2,"i_data":"DBIWxk9iVFcLsxbhpjrlBd157ZZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":899,"i_im_id":1936,"i_name":"g3C2HgCVqKzbG4Zn","i_price":34.64,"i_data":"qiU0HiEYfxi0zNCWd38mqYHH5N5uXT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":900,"i_im_id":120,"i_name":"tfdyDbfuq3Bfqem4lq","i_price":47.38,"i_data":"lJGGUo6DsVHgFkjqRbTcsMCusXyIk0K6th5Pkcx5n15"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":901,"i_im_id":486,"i_name":"RvaLlDEILeVs8fn5y9x4dhg","i_price":22.79,"i_data":"9RldwT1EyPtmVdwb8IxMA4nfW96g8mOPWYheCj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":902,"i_im_id":2242,"i_name":"GZvjdWZKmC56ZcCsUT25cT","i_price":4.69,"i_data":"QuXh4Cw08HhmSRUMoWeoKYP4LkBGLhtfJ5QXLWdAvb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":903,"i_im_id":533,"i_name":"5OCb7j0IfRYaPjHbex9wC","i_price":37.76,"i_data":"4Pi0yRmYxyYn6A6KdcTF4uPXTtfuuIPv2qXForiginalL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":904,"i_im_id":5495,"i_name":"uUp8nPNSheg2zdf4MsOsOShV","i_price":92.51,"i_data":"dndAoriginal2vPX4IJ5YcLwaGqCa9KX1y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":905,"i_im_id":4297,"i_name":"qrvxcAkdMe39nfKtmdj5eW","i_price":8.77,"i_data":"8iV6QQjsyc6mPy9bIGWJJlmQFBYsOEi0b3aLU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":906,"i_im_id":6038,"i_name":"VWl8adVWg5LFq7","i_price":18.46,"i_data":"pK8OZdJ0ZNmGk68wTHVKbr6bYf69b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":907,"i_im_id":1823,"i_name":"aoU0VA3a8te7m3n3GPZYAy","i_price":41.24,"i_data":"jHbVcBDWg6F0iyzLLKWIlpVrH9o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":908,"i_im_id":8930,"i_name":"o8o3MRUxYQIgThukY","i_price":37.22,"i_data":"C2rhNi2d21lFp3CF50TL3OcRHAiDG3JSeeB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":909,"i_im_id":7209,"i_name":"28aH3x9EAYPG1RvrHs","i_price":89.76,"i_data":"Nob87GwPaA7kjCJpK5yEdCjUjUiO4zqx6dnlRV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":910,"i_im_id":6371,"i_name":"oHmIL1TqNdobgO7di","i_price":4.31,"i_data":"6v2EFp3r0y8i8A29kdTEzDvNwWWVqcmILzMnAX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":911,"i_im_id":7435,"i_name":"7z0MWQSy1GZhRNlgBho","i_price":8.17,"i_data":"iwPZ7BDf3PDkTuhLhUD5Ab8uQa3Wvx6LXcKwXX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":912,"i_im_id":9367,"i_name":"VkwQveeFrNMvgeg0eLXhMw","i_price":32.8,"i_data":"Av5gGv7zUy0Ozq8KtTnaEN658E8f1SFk9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":913,"i_im_id":9726,"i_name":"5XLzOBNP8xhci6ABduY5WJK6","i_price":35.63,"i_data":"eqWIMLyLAwu0Oa547CAJUDzKaYzBl7vCN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":914,"i_im_id":8660,"i_name":"V6HurSZTOavkZ8pGs","i_price":93.12,"i_data":"jLF7hRhTyR54FFxnUo0WKaQGsgcoXLO3ySFqHAt1NAH5qQKf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":915,"i_im_id":6186,"i_name":"T4CuDNhqqNCKJdnaevz3hHq","i_price":17.65,"i_data":"t07hYWgjToUw5RNnHVcCrqb09soLQlKtb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":916,"i_im_id":5471,"i_name":"bPKwejTJTCVkvNFdp","i_price":19.73,"i_data":"hOn29U4ecphos5yZ8Y70eOXKWCHaRtTbyyHd4gk8lyeb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":917,"i_im_id":9638,"i_name":"0I5ILKiFX2LLbAaISFr","i_price":50.47,"i_data":"N8rT86zmkeEvIkSvcDmyGlsgcCOhw34vavXmA5l2NO0NMbdyDK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":918,"i_im_id":1059,"i_name":"ANJGTo3gd9sSWXuB8","i_price":64.75,"i_data":"b51ju04t2rOQ60ssNJZwL2uTXyc6JM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":919,"i_im_id":2056,"i_name":"kNN3Y9vFapW6AQi7Iq","i_price":31.7,"i_data":"73LxjuAohWRWEDdNK58RXob0SvbqWchGG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":920,"i_im_id":9829,"i_name":"h3s7EHQkCrYLpxo","i_price":45.18,"i_data":"nY0dj2MGFEDzfQmKnQoUoTuB0hKzJ2x4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":921,"i_im_id":1963,"i_name":"SrETF87YVmopyoCu8vIa","i_price":93.73,"i_data":"wdi9q1elbyH0G8VJjYoFDExNZORuO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":922,"i_im_id":4450,"i_name":"8wJRn5bkPT3GO08dYNI5C","i_price":25.14,"i_data":"MdRQvHvnlDZ4TJuaEKuEln9RremlmDlbhAUwUjYfuw9nuqlL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":923,"i_im_id":4499,"i_name":"ewQ3ArVcOzw1ogm","i_price":13.74,"i_data":"U8hDhPVLFSrqn32SHrwk5vkjDb1e06ButuG5SNFOeAQsv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":924,"i_im_id":9334,"i_name":"9B7GBbwhGmR4d5qudx","i_price":92.64,"i_data":"CHiBWy2XtM73wAXlX0ODD9vzcqiXR9ZQUJgWAjizOC3y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739202,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":925,"i_im_id":8505,"i_name":"OBEZPeqo6M0hWyfTt7MB3i3r","i_price":72.21,"i_data":"nivbzE4uKp1xDPa3JmJlaKMhuXaUl3enzV1AlEsFWP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":926,"i_im_id":736,"i_name":"nDHKPelpvbdCQ1MEr7q","i_price":92.71,"i_data":"sZxoriginaldPmXw2G91bTBIXZmZK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":927,"i_im_id":8120,"i_name":"kZf5TBY3Y9EoQlGLKj30","i_price":56.39,"i_data":"PvMAYODtiEILR7r7yJVbQFYMflNuxBCdyc3MWZxv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":928,"i_im_id":3619,"i_name":"rEMmThyMzZGfakSOl","i_price":75.69,"i_data":"D707ztY5Q7uFPGByRSJ9fjjJD9xYVsNnZkF1YGyWzKR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":929,"i_im_id":3677,"i_name":"7ry0140hywcAKaoZg","i_price":40.62,"i_data":"ErnHbqhRYkZIFfRAf3TkFHR2BlJm9cczcbnlk2zu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":930,"i_im_id":8791,"i_name":"N8mGSPek7hefjU8NFOGBEje","i_price":92.38,"i_data":"fdq5CGY0k5r6ADivQQkGlOaKPhFkJHsrN6sHhePaQqKkX7ahE4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":931,"i_im_id":6278,"i_name":"L744BFfiGgsmDmc9tyLVgX","i_price":1.54,"i_data":"HB7KXSIbGSuForiginalSgKFIh3MmbnprtquV8Tzipy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":932,"i_im_id":6775,"i_name":"6O42vF13NWukYGum9eNzcv","i_price":39.27,"i_data":"7qvJ12EaC4ErudpTEeNzFHFexyb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":933,"i_im_id":4743,"i_name":"Nr2ATnsW0soVDcryfTx","i_price":57.08,"i_data":"9fbRVnYVp0qEnHnqa8ulERhw1S1OqD3W3JzyRoJkI6bGDn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":934,"i_im_id":3028,"i_name":"9gGgeP1EpEVELrmWrkYJlPz","i_price":86.51,"i_data":"VIh7FJcnFi32gNhCvV9dfjX5q8MnLCneIb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":935,"i_im_id":6336,"i_name":"Svv5voiLn2TVRUDWmHf","i_price":27.4,"i_data":"Wx6qC0sA705oU8Lq1Sxiusjfemo4AfMk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":936,"i_im_id":3765,"i_name":"2RPE559VzWN0G1VAOCYmKO","i_price":71.21,"i_data":"K4imfYYTEPY7GtSnaOTDGOleOW5ngjIBWoYeu5trrY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":937,"i_im_id":3996,"i_name":"X1g0Fa783sy2IM2Pc11VHqtr","i_price":6.72,"i_data":"l9Gngdr2Njb8cAgoriVlmH6WqCRrBgcGPt1kwFwb7lY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":938,"i_im_id":7912,"i_name":"hIR3LKeudaVVMqmHr3lKjTOj","i_price":25.78,"i_data":"wHAuhqGtGdIgTCPycSpBNOBA7ZyiJ9gFKOH4Zmx8W3EEVo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":939,"i_im_id":4781,"i_name":"rIQEnqBeUWYwkHtHCXFbJte8","i_price":91.61,"i_data":"a7mF8WPy5inTk8lR6gL37NCpa74Dv39ZL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":940,"i_im_id":4495,"i_name":"Q5VAqeLHs69lk9wfRkRcWJHU","i_price":25.63,"i_data":"cy5IQnveAYhOYueXMDP5fYCJxTMJVjIOEWtWm7VSDONib"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":941,"i_im_id":7219,"i_name":"NpKvHp3fE1kKFUk","i_price":33.45,"i_data":"A3BoojevQxbS77CNI7IgDcdKdo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":942,"i_im_id":6913,"i_name":"j9J2C4xHsCpHqIC","i_price":22.82,"i_data":"RIQv4x6KigtzQEaWIS3fKvVVQF8JKFJnia0iu5F"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":943,"i_im_id":6192,"i_name":"XKem1DpBqcsaucbQq7f","i_price":30.02,"i_data":"olmVCTMZr6VPKQlgiAyUUZXbXTsjQ9YsU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":944,"i_im_id":5047,"i_name":"tKKJfPuqcrfPcCI","i_price":17.08,"i_data":"6Q7963sqzQ8RuGZx8ReDTV1o9eLU1C3kNb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":945,"i_im_id":5813,"i_name":"mUwd6Bxd6foSy6m","i_price":61.36,"i_data":"MriMOfJNJjdXxhioCoriginal80L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":946,"i_im_id":1009,"i_name":"OUFrIkHduLknIyp","i_price":21.94,"i_data":"kRSHsA6ntTDn1nS14C84LAMqGh5e53YpsuxhspzEtkrvT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":947,"i_im_id":2934,"i_name":"vhgoVjJUlBXDFdZCxzsaya5","i_price":83.37,"i_data":"byP9BgZJ96c4FtXOk1dQeehbVfO1rdebglGHbuMur"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":948,"i_im_id":4097,"i_name":"RsVtYNU406AKgsJLXI","i_price":6.11,"i_data":"NL0tdMjDRAMWRINuqsxRloUZ73iWu8x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":949,"i_im_id":8346,"i_name":"Mu47DfHKYL6EtWFGPjz","i_price":42.36,"i_data":"POqM6uEMFu8riZO0koiZb68b1xoriginalzvpqYY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":950,"i_im_id":7013,"i_name":"61mrIYj5GVFU69Hg9OatBF","i_price":55.12,"i_data":"SFnOBc5up50qMkfZP44p2NczHNbox0UpD2nys3R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":951,"i_im_id":1418,"i_name":"6PgMxngZPNRnj23GWJUef8","i_price":78.56,"i_data":"YvNnkg9OkkswgmNbQddO2gVXAe7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":952,"i_im_id":8699,"i_name":"KOr9ndPJ7CMWutBPpoi5y","i_price":60.95,"i_data":"VRnuHOWO3JRmGSjcl0Pwtt5Itxdc6ItZjyVxEu36m5dty"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":953,"i_im_id":6857,"i_name":"ZFJcROx8weBQE8ogoQM","i_price":2.25,"i_data":"rC9DVCbVT0MJ3FHUdluyK4TwuP0wnvHPBUho"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":954,"i_im_id":2097,"i_name":"N3NgiuL0AoTHVNcv","i_price":91.48,"i_data":"myL9Wkk5bf72ZRoriginal2foTrQfEV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":955,"i_im_id":9358,"i_name":"yU0rQeGImscj8aaVrHmJ5","i_price":5.68,"i_data":"VWPOdfgnfeJ15YZngXbnZ8O0neo5riqYZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":956,"i_im_id":3958,"i_name":"DNB0kXgywLwfC3tUTgQ0l0","i_price":32.34,"i_data":"dsx6qT1ZTwUJ0Y0Lcc8dlx7JUBhF6uqZCgV6iONoDuiUVbmjPt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":957,"i_im_id":9240,"i_name":"Bo8Ofln8Jl7ZTjIv","i_price":98.75,"i_data":"6z9dPvh6whxwjKlNiaXaC6rh7THQw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":958,"i_im_id":1921,"i_name":"Q0jVg7u6A4ZbN6tQlXsjXSq","i_price":28.13,"i_data":"kdbBVhLVcpuLyaeGnvVdlenY1N3gKRL3IyjUsMxCLrL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":959,"i_im_id":5859,"i_name":"KLmQ3VOEm9aDwthuuAy","i_price":57.67,"i_data":"7KerYSU5QxOQq03CHj1zpEGqDCSSPltTGPKdUikt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":960,"i_im_id":4246,"i_name":"lDnlB0YwIvkkGoe5x","i_price":15.7,"i_data":"cioriginal9wTmY4dJYpMyFmIpmpgLFDkn05V2G"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":961,"i_im_id":7859,"i_name":"JV1BoOxS2JenbE","i_price":4.67,"i_data":"6vcnEOhdfMzeJjmSequkhwtPcm78Z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":962,"i_im_id":8281,"i_name":"9G614pk4d5F4asNDl","i_price":3.34,"i_data":"YCUnY2eYDYvlsGelj61SOQyIOpdX8thTCVFnU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":963,"i_im_id":4837,"i_name":"K45XeAB33PBmNvrR","i_price":23.06,"i_data":"FBgfakECyxbZSh9agAkzmKfYrwhzhQmevW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":964,"i_im_id":1958,"i_name":"SQ2WhZJQs5Un8X4hk4J","i_price":90.42,"i_data":"LY07daYoXgSwEbRhC9UbAO5BaZ1AoriginalweNeW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":965,"i_im_id":9967,"i_name":"jMGD2Mer803aBGExl9FaD","i_price":43.51,"i_data":"F7MIk3NfWXr0IjN3GXFIQZ1MdBpLMK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":966,"i_im_id":9502,"i_name":"E4XCGvwjfaTDHjyiLvflhHOw","i_price":78.11,"i_data":"s8gVH4originalEGlTaP2Opa0NbZaDBa4tEf3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":967,"i_im_id":4519,"i_name":"U3ilJloVcABVb1A0K4fj","i_price":92.2,"i_data":"7yrZYzPkbxvs5KfNJoTxQx8riVnOWqG45w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":968,"i_im_id":2565,"i_name":"4Hxpz7iX50rxW886VhHXigw","i_price":50.71,"i_data":"fRdX5ugWZV6QmhCNfrsv6svp1X3n4diAJwEdiYw5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":969,"i_im_id":2626,"i_name":"c72RcUM6kquID2BKMlI","i_price":29.04,"i_data":"IKD2AKluJJPyw5RU69L6bGTgWp81NKogLioX8v52IyQj9wtw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":970,"i_im_id":5711,"i_name":"gbRk5qYfwgDOh1F","i_price":47.25,"i_data":"YZc8Uzxgph5HKWpL1ZBJwfR7EW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":971,"i_im_id":9856,"i_name":"C5VbStJKARPNGGF","i_price":25.29,"i_data":"bGgdoriginalHiHY2d8J0NzVk81KxEP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":972,"i_im_id":4701,"i_name":"glJCE2ic334kqM14sckDx9Yn","i_price":20.95,"i_data":"NlbYmsk1aBBcYplPeIiTbmH7eXR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":973,"i_im_id":6669,"i_name":"DGe1fA0tG4x0Y1F","i_price":88.76,"i_data":"Z5EO0SwkNkGVBiucRCEKkpmpVGtgIxTKfWQ0uXcR7HethV6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":974,"i_im_id":7858,"i_name":"pQFtR44HoQ4Grd5gQTB4bR","i_price":11.73,"i_data":"sCv0o31yYvvaMOHJVIa2t6dtDytOA93Zt877Andr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":975,"i_im_id":4370,"i_name":"wGFRDl88owz5S6qKsFfLN","i_price":66.7,"i_data":"lojIeUm9v5FKyKyQxljFZ71aXqH1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":976,"i_im_id":913,"i_name":"UXOFRISeI8Qf6rmd4PEP","i_price":50.24,"i_data":"Fi2JBbZHRPXNoriginalzrhMJWK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":977,"i_im_id":3753,"i_name":"Q7DiN5QUywPkHOoH","i_price":20.57,"i_data":"jvV1WjqXg9z2CTjCLkJtiXePf3Qjt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":978,"i_im_id":225,"i_name":"DL5sVnriKozl0Xd","i_price":13.3,"i_data":"pWwTtTXIswcBn4A1BQ0wvcC1Wv5RYf9b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":979,"i_im_id":8681,"i_name":"rpYWiYZfjTIxOr","i_price":75.34,"i_data":"Dcc2nEDAsXm31q2skn8AZaZSFQxq6UZNqV76bW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":980,"i_im_id":7333,"i_name":"i9ISiNUwd0J1lsHt9D","i_price":70.68,"i_data":"uJhOLBOmT0lLa8WJ6Clmn7WPyXkyC4zO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":981,"i_im_id":5234,"i_name":"Iq0jbJo6iysS1WaKpQJ5CTjT","i_price":82.41,"i_data":"movtbSrXCJzCjpTMU8qB2VbvXV92hQrbUvPi3TDR6ToZb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":982,"i_im_id":5869,"i_name":"g84ZHD9K0suew2BUFTiFz","i_price":71.23,"i_data":"m0VIldl5BwGtlFoXR3HbUUNmQ9jIBeap23K9Ob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":983,"i_im_id":8056,"i_name":"dmXu6Jusowkx2mT7p","i_price":54.51,"i_data":"XDzRxndFMOh59EDhMl1uWiircgIt6wbheJxtaCwF8mWu4VR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":984,"i_im_id":8282,"i_name":"DAbqyatqL6RNfOU","i_price":94.58,"i_data":"sIoZz7originalJiYD3e1ARBf3nfbVLuiTKmMVxjnvA3M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":985,"i_im_id":4650,"i_name":"ypUZzU8lhQP1n3xYR1NIb","i_price":28.1,"i_data":"KyuoriginalRJGcCDSRjWTnYsF6InFICoJEF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":986,"i_im_id":7087,"i_name":"QpXjh9Z8XiB9FH3oTCxoV2bm","i_price":45.99,"i_data":"Sk1iXU6zIVafMsXNipVVWkDvRgYwSGhRO0B4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":987,"i_im_id":2220,"i_name":"LW2MUWf4IsecVn4cc","i_price":29.86,"i_data":"uNMF22yKDSBs2v1nNZ5F1iLgLwDLH2Qb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":988,"i_im_id":727,"i_name":"hTSKR6g5foDADbVPsoSh6","i_price":80.5,"i_data":"MG1QT0vQLXOHT8Oloo2TeMZp2BBjriBw1r25q8X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":989,"i_im_id":2397,"i_name":"s1Xdx5NRTT8P4QjS","i_price":92.56,"i_data":"JoafzFmqJrTjV8TYmR9gkpDkhBcppFybRzzyxiVvsVRJO2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":990,"i_im_id":4475,"i_name":"aakp3Rb901rsOLDuWlm","i_price":45.86,"i_data":"GAEpCfr0imNimF8WJACmWAUd1GFeVHj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":991,"i_im_id":5700,"i_name":"jJp8KSiZVCrej2mX","i_price":30.22,"i_data":"uybwIINaGBIEZyIaRNfO9GupafdZqdf7mxBxwxSFBosH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":992,"i_im_id":4415,"i_name":"1d01IShXdDLXxsq3","i_price":43.41,"i_data":"7rwu8O6xanCqbs3SR5vQtq00XHWtwVxboOB9S6oAc1JU4nj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":993,"i_im_id":9825,"i_name":"DiEiunaSiCY6NupQphS","i_price":5.59,"i_data":"VnUs14PScwFLeNQHacy1Yp2Bf1VwPBljVaaTFINh4dfa0AMGx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":994,"i_im_id":2121,"i_name":"oOxyniSQg7XkseS1dVQuzF","i_price":74.39,"i_data":"PMgwKMlTPBkBf45BLvRAAx8UyuyIXPM6m4p5V6sey9ub"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":995,"i_im_id":5990,"i_name":"iZ0rQDWFZDRkpd8cu5LO","i_price":90.78,"i_data":"nM2fM3HH5a6QBwpD7I5OeG3Und4VRSYE8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":996,"i_im_id":4475,"i_name":"dFEHtMz9mS14i0Yh","i_price":54.97,"i_data":"dlOPH3d6QxSbtsyuvBvC0vjlBo8LKU0r4Ah7j7uGZJSPjmEOrN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":997,"i_im_id":4435,"i_name":"sgjGMbb4FA9dHaf","i_price":34.6,"i_data":"lRakEsabgi89gT2yCE14ny7m1CYPQFRLT9F5UkkwxHN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":998,"i_im_id":5588,"i_name":"sctez1OUXW0NHr03pfli4U","i_price":37.21,"i_data":"lQAmDPtxd8L799jgUKCU2FDI2uTjicSjp338oyUOereZbd2xK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":999,"i_im_id":4353,"i_name":"0ZXLkFqG9uJ2ZqDBVm4W","i_price":2.39,"i_data":"IylwSdh8y30A4wK5WuP1GOEFehcJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1000,"i_im_id":9420,"i_name":"QkKno7wqhsBq1MCqL","i_price":66.26,"i_data":"YOpZvRgtWls2sUl1EigPGq7yYn40wsN4PuuhPw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1001,"i_im_id":7851,"i_name":"7aArq6vlvvcjKzx0D","i_price":17.21,"i_data":"wU83mGCLPuCWltzwNrj2D5SpO5Aje1ACQE8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1002,"i_im_id":8357,"i_name":"noMRxGcZyhr29PjuwAosgc","i_price":99.32,"i_data":"4Z66Sj5qesyQJhzQRCfpyUOfRyRjLwLmWQZzIEW13K5xiKpbH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1003,"i_im_id":5578,"i_name":"sNgMEXHDy2xYhk6gRX3Gy","i_price":86.8,"i_data":"yio4XWwRRY30fvoQrynaS7mmdBlWLeIp5gD4UzRah8m8KpWF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1004,"i_im_id":3083,"i_name":"NlqtcD6OXKKiTydgD5Ifc","i_price":95.02,"i_data":"fuqX8RynzRGm3it74M9hIwCXS8lINNtO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1005,"i_im_id":8368,"i_name":"BBtHQGFadWW7TY","i_price":97.53,"i_data":"4svWZTQx5fCRmTSqEsSMPuIrkQxtZcv9T8s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1006,"i_im_id":1252,"i_name":"fJYuteqa2fygw9prwdSV","i_price":74.57,"i_data":"BgFgzlWgnDIzVOdjYxS4g6y0bEZ7HvYMdP2N3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1007,"i_im_id":9556,"i_name":"VKLBDIsd6zpZOu2","i_price":20.01,"i_data":"cHxTjysL3jQK3HjezvzrAWOmsAKJDSDMNvC5iLs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1008,"i_im_id":4681,"i_name":"LT99XhaEyiECpTlgnjiF","i_price":24.48,"i_data":"lDB6WMgIaN7tjGvKQDROFNKE5O"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1009,"i_im_id":9026,"i_name":"l3K8eizT2TIUALIMiSW4P","i_price":1.68,"i_data":"Is6LOQ7mE4mHsisijSeHqzbjbRIPrExEFwv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1010,"i_im_id":9363,"i_name":"rsnpStePhGJ5cbc0Qp","i_price":2.63,"i_data":"LXXnw9e63MTdYJCCwQV0KXMHFb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1011,"i_im_id":7448,"i_name":"leawxU0mv8nsapdNNqr","i_price":23.25,"i_data":"y9kZN86rEtfRb6VaAPAnCsZcGOl1stp4FLygHwnK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1012,"i_im_id":8297,"i_name":"vLIaSosKTKfP2x","i_price":40.29,"i_data":"gq7DYi41EWYBY8AB7UQcH4csYBJPBnqxuK061fyqQz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1013,"i_im_id":7840,"i_name":"2IusJjiygZinz0huhs1Wyx","i_price":72.83,"i_data":"soebzd6E1oqLg4Q45HXYfZFEJMrlrIc3ouITsrWSAvKgrqyp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1014,"i_im_id":2024,"i_name":"k83C17NqvbtRwFv99ystjjG","i_price":45.46,"i_data":"BwGKMVxcJj3sGlJb7HuAEE7vdPnz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1015,"i_im_id":9459,"i_name":"Jj2zRl4A17PMyvO","i_price":73.86,"i_data":"bSbSwUqlpAJMf4Yw18KR0q9IdQyBBe99kbcT3IkRa5nEHUN7Rb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1016,"i_im_id":8784,"i_name":"LKhqXVu2J2FQIVWq1La","i_price":86.27,"i_data":"CnYDKugXeB3EqrYZiqS0hsctiAwFzO55"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1017,"i_im_id":6732,"i_name":"OxL4xjvvEoakC6o0SWFzLv","i_price":10.34,"i_data":"bLoAANY3fHavBHiTNF8ILP1dqSvtvbx7W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1018,"i_im_id":5646,"i_name":"qYf4XNzDv5vUlz","i_price":89.64,"i_data":"ZOqAA18q8SRCUjaQYUZi8912e2pubQZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1019,"i_im_id":7294,"i_name":"xjMmd163QZIDupNo","i_price":56.1,"i_data":"YthoN8Tfj9jQSmDLhGFhrJt5YvgAqnpvIci4uF7wskM69zjDeX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1020,"i_im_id":8397,"i_name":"S5QQcGTJ2Ru7VhZgh","i_price":49.49,"i_data":"798dA3h9MDygMEtJ1yb2AMiBCnHfmXynmse793"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1021,"i_im_id":796,"i_name":"l4uiTfaSCWD5rwe1uY1","i_price":90.01,"i_data":"388xmii27aOraSpseNmWvQ8kRykXgjg5xhkCuEIhk6kN614y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1022,"i_im_id":1174,"i_name":"LxR1rq2XAbl2LaUfP4chCpoX","i_price":43.44,"i_data":"si4ZUK18tSbyvEN0nu1fLbMNLfsy0kmFP7BMDw9P74xfIjmJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1023,"i_im_id":190,"i_name":"nU46pBloZd9IzLvWqkWw6KQ","i_price":43.35,"i_data":"QKGJAYtohFo5fxdmTr16U0dXs2UOmeo9ZxRgwsa4slDRqb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1024,"i_im_id":3748,"i_name":"o6k3ytLBgirhI9","i_price":30.6,"i_data":"tQs1JKBG47IGATWon9ubEsJeb8m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1025,"i_im_id":5425,"i_name":"Bz47cqfPkoXb18trv","i_price":68.65,"i_data":"X4z0UG2NR2tetJ4MC4uBl33D60V12utT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1026,"i_im_id":1422,"i_name":"vltilX6riOX9kpMzBna7w2vr","i_price":23.29,"i_data":"tqjexyPQwASpqpnOEI3r7j1tws0Lymbov5yBj7Occ7xA0xwuy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1027,"i_im_id":9318,"i_name":"JFU4cSQZHoOfLq1vUWxEq","i_price":72.63,"i_data":"INGLJoin9TTI70p5r4hdhyr5XTnP2GwyXqHZlPcclKQss"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1028,"i_im_id":1380,"i_name":"eAcHdsfyXS8nxYWk","i_price":58.16,"i_data":"Mcc0thG5iOnm7FILzdhCS0cUj3UFoSoX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1029,"i_im_id":4349,"i_name":"Fv8Cf0UWjc9m9t","i_price":86.87,"i_data":"bDuSW2tWnpS3EuP7jd9X82U96jp1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739203,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1030,"i_im_id":9585,"i_name":"eaDCbG8rix0gzeKR5DQT","i_price":53.44,"i_data":"DD4mVwuRccCuhkJ5VZZwgnehdQ8ua8LeVTIEWGJLO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1031,"i_im_id":8619,"i_name":"SpHmNpcYtOyMlaS9","i_price":38.16,"i_data":"KgH057u2s9yx52uktgNmVRAAt3n25zGA1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1032,"i_im_id":9940,"i_name":"m01ChpMoux1Lqlsr1wTgC","i_price":12.43,"i_data":"AVteHrfEPgvJ4rJDwS7PAEz8fzEq7NNWr7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1033,"i_im_id":7981,"i_name":"e4rQdkzeNRUbIKyA","i_price":51.64,"i_data":"WEuu5LwOxY12KhToYBh1m06w6p1vmXPL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1034,"i_im_id":9041,"i_name":"6EVCwF10JoQEpwa","i_price":80.64,"i_data":"QS2We0XKFEBAIPz8NHjfiFdHl0iszwTev5uCbuuYSPOzyNQ8aO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1035,"i_im_id":6268,"i_name":"dZsyKuI6hJF9DzCd7ga6","i_price":39.23,"i_data":"g58iyL7LNII575Fakg3B0SZiROXn6m7hfJe7wTIYokKjdu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1036,"i_im_id":4006,"i_name":"IIBUGz2aTlI1llMg01c9","i_price":49.68,"i_data":"mYXxNa7qZMc0EpksmmTE80mfVdyD4ofCcasAByowP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1037,"i_im_id":8451,"i_name":"89NEZhJ3UnjPcrATwB1tZl","i_price":34.34,"i_data":"PaXKzf3gJYsvtBdMh0h2rGnMov9rMXTESAGgkuXnf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1038,"i_im_id":9153,"i_name":"VO0CHbaizesAMr5aVTFgwFR","i_price":97.37,"i_data":"b0TVWN7cJ3T3opXI0aLUMzIm4wgA1doriginal8P2c5RFJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1039,"i_im_id":9940,"i_name":"6Fxn98E4iF3jfFC9fdcAaV9B","i_price":5.04,"i_data":"j7bBuDbSDMXGNsN2TB2skmdaQGU9mb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1040,"i_im_id":172,"i_name":"uLAO8qSC1TM6HXnQqQdXep","i_price":11.85,"i_data":"J0qthH6Vqvm5wswsdGwJELWYtdXlQx717RDUBu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1041,"i_im_id":5495,"i_name":"bB64XGJKBFr6Qo","i_price":47.14,"i_data":"b3q1TJtXacqHW6cmZco0MQEwtqMw23o9UIlayRiMevU7tvVT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1042,"i_im_id":1200,"i_name":"N8WFFwgUwbpZLj1koJIrx56Y","i_price":80.99,"i_data":"3YoU5rveUBShNumpGXQERnCQmreCaQJKNQRPnYWPo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1043,"i_im_id":2479,"i_name":"j6Y6cSZZrymxsFc2","i_price":66.55,"i_data":"etI5dOvYi2Ua1yKCmCyhRRHMHxzcRiTqL37tEma9D9SXTZnnb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1044,"i_im_id":2429,"i_name":"Wsd9WNkUS6en4KJOB7VUY","i_price":34.7,"i_data":"bHFNeP5zx1Fh4SEOFwls03BwQ9LmlFg2OA7y7Z1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1045,"i_im_id":2347,"i_name":"TMJNgyJGcHo2bzoM","i_price":90.89,"i_data":"az2gRr7EElIQpsPIUGE3LIVJj4PKMojWuB8caAolrYSxTKsJiW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1046,"i_im_id":4127,"i_name":"INepTWy7A97d36DYf","i_price":50.37,"i_data":"VBEYX5azDwEKOkJfDGgjJcp5AE62xeP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1047,"i_im_id":5545,"i_name":"0xrwC40rHAQIpx6jplVLR","i_price":54.81,"i_data":"ImNHynVOqt0cHfFjQHA6fryXjj0TOcIptZSyxxsSQrALf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1048,"i_im_id":7984,"i_name":"WdWGjEOPu4YJWtWfehMCW","i_price":14.49,"i_data":"Jn1GBoKfVfA1JaUISXE7lxV9A5eITcosmzR1Pru"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1049,"i_im_id":9970,"i_name":"desg7VfLwOTSLE27HqYY","i_price":47.72,"i_data":"XbfysDabuKPyCqD1iZxdVhpt2jhOjXKreqWkOcI45PSy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1050,"i_im_id":4003,"i_name":"9I4CqJfers5iuHSJA957jx","i_price":40.08,"i_data":"zzLgjqzUZM6Nek9DBt4hMrKZBZm1jDIFui"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1051,"i_im_id":8137,"i_name":"67xpLHTxQwpOlYZQwRri","i_price":84.88,"i_data":"JhfNMIga8mUMITeealPeRIkHAlb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1052,"i_im_id":1938,"i_name":"vloWB3A3HY57KtTdbK","i_price":19.64,"i_data":"rTox0V1ndy1zdnfuaT8c9Dicew9sO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1053,"i_im_id":3261,"i_name":"JVz0f7DZ12nY7SSRApSa","i_price":57.36,"i_data":"pIrQqOhd9f4tZeGT1WVyM1c5KQE1SkvB1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1054,"i_im_id":185,"i_name":"5d5GxAD5Xz02SQM8qi","i_price":80.04,"i_data":"3mGkmuEDHSUDNN1rhNYBziKzgjlGuEFolIh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1055,"i_im_id":4534,"i_name":"39AvjAgtuA6Sy8BcunZOv","i_price":58.17,"i_data":"K1XHBxQMxskoY1DOyuFckHm5CIEB3o17WYoh0Gj8k3u5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1056,"i_im_id":5790,"i_name":"WHA8uuwDUng9XdNbl","i_price":42.82,"i_data":"Sul3ya7Iq6oxDkukZqSpQOU9Hd3zN5bjg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1057,"i_im_id":6962,"i_name":"X31i6o8dCAEbb7","i_price":44.5,"i_data":"UjPmRPWiGJw1ia9n2QVqZLz5xKZq5d14V3Kp1O3pWcByS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1058,"i_im_id":3020,"i_name":"U0DQU5LOcFHKXNqL","i_price":60.45,"i_data":"nZgqD8ROHR6bxJY1mOUbn1tm4f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1059,"i_im_id":4615,"i_name":"Vwjufg3E9juTrQ","i_price":32.49,"i_data":"FY9AGiIGmWM5phpxRlCmDRAucII0nivkyMfA1alhIu8sq38m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1060,"i_im_id":548,"i_name":"CtmKhoBRnKWRQoJh","i_price":19.52,"i_data":"Ht9Nsz5e8xSjUAd3aWa4Z4iSr4DtXWUoyT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1061,"i_im_id":9769,"i_name":"dzp2Sgi6QZxxLejXi","i_price":31.94,"i_data":"meburpe02TmiFEtkG7HFiXIw7sA52ESg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1062,"i_im_id":2981,"i_name":"K4iCGbrNbyQDJKjjcf3tXf","i_price":4.35,"i_data":"zEcJUa0m00OFhi9tip9O5h6BBiwsFZSEi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1063,"i_im_id":9027,"i_name":"sz0NdgvFy62JNTU","i_price":87.19,"i_data":"9yDLV4V4V9EeqPFCdS3t5LaSWqRJ1lJOb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1064,"i_im_id":9896,"i_name":"XKDErHPffv2LIbu","i_price":99.38,"i_data":"e8Zv3yHAOr2stCdSBIVrSgQWq4JuIbYdfL0iNAQcoriginalbq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1065,"i_im_id":4667,"i_name":"fC0pOjJCEzNkLUJC0jpm5jI","i_price":69.03,"i_data":"xinK3kKqeKcuYTp0IgqfKdjat4An3bsGQpJTIJgTBNziuR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1066,"i_im_id":5755,"i_name":"z3CNwWMBczlLeLQTXrYhxhHF","i_price":38.29,"i_data":"6tB0TFkUB9MLYC25Zm7poTGEVh5rFq9fBXJIH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1067,"i_im_id":5740,"i_name":"XoEdUNaVJbjkFdT37bsY","i_price":20.88,"i_data":"aBzK078b6lh8vslDjAn8oeMjVVBTvsY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1068,"i_im_id":7722,"i_name":"TBtoqNTBknbpS0ThxMFS","i_price":60.9,"i_data":"36zUetD0A9c64gnPlZGi1hiwFMsrM1cf1TMpCCXDfoiqlpWLd8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1069,"i_im_id":7344,"i_name":"maQHUnit2wH5w9oKu4","i_price":42.08,"i_data":"yIqtOpuaennVHYkgxdTtvFqLtCUwft3hhNDrNGi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1070,"i_im_id":1067,"i_name":"DdbzS1Pc0I7Sx2I0bwiB6o","i_price":63.43,"i_data":"hhRe48oduckw5oxWnrpokiNPc2O6oR2sELpY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1071,"i_im_id":5274,"i_name":"pyHViBYExLdKV4E0k","i_price":90.25,"i_data":"ERyyTKOZnBjXbNDTLU2Yvd6gIAdnu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1072,"i_im_id":5704,"i_name":"KXOK4BPnEVLuFb4ictLM6","i_price":30.3,"i_data":"YQtWS1kQ4t4vvH5fUozkqHUw7JW4DdIs3x5trvf8TmIP7M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1073,"i_im_id":4311,"i_name":"ZbNlY0mTCxv3NmWfmA8DaQ","i_price":88.88,"i_data":"PBOO13FMR3V7SWqnK3NzC9BJSUD0BYVr76qub"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1074,"i_im_id":6509,"i_name":"9IrUrS20qjpQeoQL","i_price":18.29,"i_data":"Agoir76HzWZf5Zhwy31J5E2826dQELa0iy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1075,"i_im_id":6458,"i_name":"qhXD45Ge8KYXVKkBnl5AnUbi","i_price":28.29,"i_data":"C2sQSOfYlMOYv5qD5RaDaiWqFw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1076,"i_im_id":1240,"i_name":"wAWdZR2piZxtJYmLeJu45X","i_price":1.7,"i_data":"rItmjA53m6HTxsxtPINtZ7GMpqixAdYYb1pH4C852fgk00v0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1077,"i_im_id":4215,"i_name":"07aYp3TpS3pCsDM","i_price":75.23,"i_data":"BIcZjVHRnuK4h2HJoFxQjpSVSTBISgw1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1078,"i_im_id":1487,"i_name":"n6MevHte4zHHaG","i_price":11.35,"i_data":"DM3lSj9PsBLgyHKU2aMVISHjVUvpp38B6vtNqqOx5EfukOXYYY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1079,"i_im_id":240,"i_name":"gaCAaBGswfXtfCBfPlDE","i_price":14.47,"i_data":"OF2riFXtx8TPTZ5LtDi0WtrnbHAdCujL310rqqlIV7gtD5qr5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1080,"i_im_id":7946,"i_name":"27yhzsXIpV506A2","i_price":44.83,"i_data":"qB2O2ouZPqARr2tAYtNyXiIi47RpL4originalkggK6drd31b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1081,"i_im_id":3115,"i_name":"k8d4rHX37sgfugxa","i_price":12.58,"i_data":"eHZrwN26WI3BmGhIJhtKP3zOER7Rw8FK9k8AtRGqENyAb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1082,"i_im_id":8600,"i_name":"D4Eg193yy1u2ab2lbcCoZ8c","i_price":77.03,"i_data":"jUdCxDMpvfgbYc4IVsqZbbPFeWAsjrzP3o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1083,"i_im_id":8045,"i_name":"0wLfOnrI3lFydeP","i_price":74.06,"i_data":"1lZfLBL8AzYAdwKY3tRLuOLhuHLwx7dPpVm6H"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1084,"i_im_id":9915,"i_name":"XwrW7vufh20Sl320nSSAklAt","i_price":39.67,"i_data":"piAkhtyScnfrf3Y5BrqMqNsDRScIk5GD9V5r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1085,"i_im_id":9026,"i_name":"WY4aAXv8f9iPwqnMSn5bd1","i_price":74.13,"i_data":"WNGZcxEXTq9uCXFLDSNuNk61cB7y4X39ZY286uSVDSZkqEVR8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1086,"i_im_id":437,"i_name":"w04nM63TBuTWx7OISI23zf","i_price":39.49,"i_data":"2M3BAMQeG5YI7mkSl6vSIgFN8MzlaqW3koI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1087,"i_im_id":8238,"i_name":"BXpSIKok1i8bc0PBnj","i_price":84.98,"i_data":"qfycnzxhWIiomOh1JDQahVFGQnL9N0bCdCXvYz9xMo88qi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1088,"i_im_id":3415,"i_name":"EIqeCV1LyTse8DM","i_price":88.0,"i_data":"wcq5J4PZg1RDMtb97ljK3imWgijKv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1089,"i_im_id":9575,"i_name":"HTp5tNSF2fGwUDB3W4MmOQ","i_price":8.65,"i_data":"5ouDkKA8DNxpWdPdnQ0L1FSyVX574hQbeWY6iC8hH0NYd1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1090,"i_im_id":7750,"i_name":"VCeLkMbFThywPsi3u","i_price":22.76,"i_data":"4pDAkMagpnIM0C4originalzT0Q6afwOiEXoam"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1091,"i_im_id":1276,"i_name":"kSpripiRtRzEgqCeK6","i_price":77.04,"i_data":"Z2HmyDs0m1asFMlAvEQOHOP7gVUjULFzoUlOP2MOJodntn2yb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1092,"i_im_id":3064,"i_name":"IzMGHgPDjp0CZ5eKrBub","i_price":12.87,"i_data":"SCntKSyNTh7ctqbcaS3jd2ZYxMgFUw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1093,"i_im_id":5037,"i_name":"N8T4KDQP3S92DG5ylQ","i_price":97.54,"i_data":"stO1JWuHlTbryWAbO3xCco84usx9hrSjn9tv3IlMeDM8b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1094,"i_im_id":8639,"i_name":"YpgR0uHiJE80VbS","i_price":84.21,"i_data":"hGy1eNcKfNgIW7mt0Khq7hllzepyyr9MGqEuxQ0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1095,"i_im_id":8322,"i_name":"jLR1L4PRfsVCik","i_price":6.84,"i_data":"gBMpZxSbst7U5aHb1SH4eGbN0dAWuROLp6Wg6qOj57rlM351X6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1096,"i_im_id":2692,"i_name":"ybDJ3X8oUNt3U4bf","i_price":4.21,"i_data":"OQqDNulYM98MPKUD27KS6KptGdSFtHB7TTbDcgpx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1097,"i_im_id":7775,"i_name":"rXSKiGRzK1sbXN97a","i_price":52.88,"i_data":"izQlmoHUnhV9kiPdPF7uXU3PqYfHPUID8dLfRf4THwKKKZi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1098,"i_im_id":6088,"i_name":"OJ0bjqXzjQX8u4l1KB7h1pU","i_price":13.41,"i_data":"MkbinDUa1MUXy1QmxCBmpzxz5xPaWFE2d5J4Ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1099,"i_im_id":2195,"i_name":"0G1hQ1ExajUPzQ2yOmHz","i_price":37.32,"i_data":"Q3sXc9jDzMojhLQCbxBUiU5qWY39SJOz02ljb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1100,"i_im_id":7718,"i_name":"Hx4VG3aN7HF1gIA89cCXoiMm","i_price":78.66,"i_data":"vUH5Qd5WkvuPL3WuTXMdAwNoAa3QJmR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1101,"i_im_id":5950,"i_name":"9cPYYTiXEyUgKUsu6uAYNBB","i_price":57.77,"i_data":"mdX8cv25ABNG2FbDIIbvHs6cvaFj63oZ2U4r1uGNH5ZKfD3nXN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1102,"i_im_id":7937,"i_name":"N8khIinkvcNCNzKrO9SFGFW","i_price":66.81,"i_data":"1JBSqP4originalZYNGVh5p9rDMH7IIMz78k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1103,"i_im_id":7204,"i_name":"cMA9992gTjrTg1Fk6nCvS","i_price":23.1,"i_data":"jyMKY7saFDbww1FRxPqgKwpaggYILgz35Cby2m7YoLUx8Qv9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1104,"i_im_id":4762,"i_name":"xAAbqdhFMj6rSoxEeXFxayWG","i_price":90.9,"i_data":"1Ea18WA3ngZKljaoriginalir6vuqMDDYTwElAhqmb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1105,"i_im_id":9428,"i_name":"L1c3MnszY5u1jMGPXLRHxHKq","i_price":46.66,"i_data":"yX1WE6HwuM3P2zYWNPUtuRfS66EKoiyCY0mLlG0erl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1106,"i_im_id":5732,"i_name":"PltQR9dIYwROa5","i_price":2.76,"i_data":"wK5qJaa0t3Kb4iDFu6EyW94188VbFXQ9i2CMuCzZ92pdlp6Kv9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1107,"i_im_id":2462,"i_name":"uesKPfmyaDjzmA3mvTzz","i_price":17.6,"i_data":"osfOyShEA84AeNLCG8ncLbrvau"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1108,"i_im_id":9612,"i_name":"Ezhqbc7At8Jn8q1RmZnJm","i_price":33.75,"i_data":"A8ZNxV2qwiWyUaoriginalyXPYX9Tg15fQ4uasSVxb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1109,"i_im_id":0,"i_name":"2p60ZsDO9Gfy9PYU","i_price":61.17,"i_data":"sysP89ZOVlDG7szj6sTH1AQVaziieLQDn2pCAg6Grd1NZmwOZ9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1110,"i_im_id":3281,"i_name":"Yk08TfZs5CcKjI9tGyl2RsYL","i_price":63.08,"i_data":"qRQctrJgQOklQjufs78rnG2YkBdk3xfc80p3S1tDt2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1111,"i_im_id":4210,"i_name":"Z0i4ZuioNIyn4VP6","i_price":75.28,"i_data":"ESTJLSJddvXRjRA6uSPcdUz1m7aP1AHr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1112,"i_im_id":4112,"i_name":"PC1Xwq9khOD7eg25XNuJqni","i_price":93.72,"i_data":"uoaSFlmk8Q8gtAMN6zXvNSPWDiWQtFctJpQF2EXj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1113,"i_im_id":1652,"i_name":"MGqAVnbVEsDaVeHy2kdiB9","i_price":65.72,"i_data":"O4j7sIa54CCsgtxkKZ2SUHsr51Pdfbw8eoTvJqULI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1114,"i_im_id":129,"i_name":"p9jPfGcJVMsEwYYpmysYL","i_price":98.66,"i_data":"CuoriginalOIPG2Ja0TwdoFGZDq3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1115,"i_im_id":5796,"i_name":"c7KB3B3mGVLPL52Qjp","i_price":30.2,"i_data":"AJQBLzNaKvt2Wvj3QJuXktYxh6NEoLZW16cAGkgviFIj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1116,"i_im_id":6070,"i_name":"8Jwx1gKigArR3EEgZJ9XmHFX","i_price":27.2,"i_data":"Bp0iZhN1biSzozCo6XZ0KCs78X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1117,"i_im_id":9884,"i_name":"fL65j4xPQMMKeFtbBXvIgG1","i_price":97.19,"i_data":"mVvMkERniA7tqXw9rlxWRc46wj6l1O"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1118,"i_im_id":180,"i_name":"Eoi9GiXCspUj8LDZ0Bg","i_price":70.5,"i_data":"1GfZ5ITtoVerZITeU0JBhAH3l921GS6fD6cyxUIBSFof8Iy1Wb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1119,"i_im_id":2763,"i_name":"h0wcljP38NtCfWlQKeWji","i_price":79.83,"i_data":"OE6YIoINucb5kfyKGonQMo9r3J8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1120,"i_im_id":1217,"i_name":"JyTJKiM6KSUJrK","i_price":87.51,"i_data":"LWdNPczhOYKWtT6OX5lqw1LBi2FQZ5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1121,"i_im_id":7865,"i_name":"TtOiVmaPwN5yMAd","i_price":84.22,"i_data":"fCv6m3XENtUJ569oS0GLjczWDHWKh5HjregAMV7CmMIb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1122,"i_im_id":614,"i_name":"FAWfHOhIan2Kg9fmzXrbklDF","i_price":94.09,"i_data":"kLtrQaDIrFMjIXMOzmPuNuZ8originald7t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1123,"i_im_id":8779,"i_name":"AsmUT5Ddf8pOhhShTD","i_price":48.1,"i_data":"yseRZkXbGko48yyby1E3vV1RV7BegFQP3hhgIACFV2X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1124,"i_im_id":952,"i_name":"T7Pzh7yR6mxxXhPoL","i_price":27.41,"i_data":"zwd6Q4k4Y7ZBLyiIRXTND3Mm0titHYNl4e8tdkYt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1125,"i_im_id":1227,"i_name":"yTa6a8QRg8ErVXd1B8","i_price":36.93,"i_data":"AgKLklLV8KtuYq6K08rTbE3WRr9DMk2rBj0f9DqaGCgkSKb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1126,"i_im_id":577,"i_name":"cvdVs87UJyWPqILO5K6e","i_price":59.0,"i_data":"XHCjb2EEXCzF2g4zxJCCXcA8YFK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1127,"i_im_id":1602,"i_name":"O6azxvTxZ8GZ0TIB3Qb8S5WC","i_price":71.02,"i_data":"AYXzPWu2jmMLXGmKzlhfTRRPoriginal3kvIHci"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1128,"i_im_id":4281,"i_name":"YXouwXXX8eEVI7","i_price":35.07,"i_data":"rOGxXVTOzoOzZBBSYhfjiXp1Mh6ZKezLPDeqaJot"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1129,"i_im_id":7624,"i_name":"nboJrtJYV6Mt3zv1B4Lr9","i_price":73.16,"i_data":"e0cnxORhJ8CXVJkEt5oxNBQCiyGSg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1130,"i_im_id":7209,"i_name":"XWFpRaXkRxxdL603p","i_price":45.14,"i_data":"cRhZtuU5M2TaIKMGog7yehCJB47ZN6qa9LYnKeuVb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1131,"i_im_id":40,"i_name":"5wu6VwjYzU2XBlGQ","i_price":93.35,"i_data":"47AbsdZndUWoriginalaR1mbxzrGM2BV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1132,"i_im_id":7914,"i_name":"0XLLV6spwwlnM3WQ","i_price":80.76,"i_data":"1FvyS2Mr8zEDX9I0hstDU8i4mx92Hm3SC1ZJx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1133,"i_im_id":4497,"i_name":"0DD7nJVZPX9K1QI1","i_price":11.39,"i_data":"ZafnyDhGaxFgvSmzlUsArsu7qntCXOJg0AgJBA9N0t43Aj6b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1134,"i_im_id":9171,"i_name":"7C8Ct1uo16Ytg4g082q3","i_price":50.67,"i_data":"o740hdh2ie99DoriginalC58KEcXAFzeLfM7reWtt3Guy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1135,"i_im_id":4673,"i_name":"3K2NkH9n6YThEGawTN7ij5","i_price":39.97,"i_data":"6P9Z3kJetI1L6wwvNVaTJaTwxSGf3iyw6KyrrLBs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1136,"i_im_id":3462,"i_name":"TztzRsLodT2Pur0Y2nRtiS","i_price":73.78,"i_data":"B2d8qPTzGOOSy7FBHkqrJCGMJ40qfLrh0aL3WJB8levSuqvYT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1137,"i_im_id":6450,"i_name":"XbKQMytue5lnPkVZSMUmby","i_price":42.3,"i_data":"EWbT0wi9NrtJ1nLXIZzurbSmJ5pDi8UFYGDgKjPSNQsrn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1138,"i_im_id":9954,"i_name":"mN3RoRjh5lBfh6vuuSl2","i_price":36.48,"i_data":"b8rLxTr1Q5PcoILNqyoriginalHoFh4gEwi2IXeTO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1139,"i_im_id":5080,"i_name":"A3dJP7RwfLbLDc9C6E","i_price":11.66,"i_data":"zFT3MKu306kBcwXpvfElPnbEJc1JB3gFoPZVagR84Mpt3l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1140,"i_im_id":4506,"i_name":"9KZXjE0hHBjjWgNsz4l32","i_price":64.24,"i_data":"WgtuB4Fecw0TLilohiC3zN5d0KOXx9VzITxtK2mRgL8U5S"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1141,"i_im_id":8572,"i_name":"8OkwaYFfoISRWXkcQSq","i_price":85.76,"i_data":"gISuzidaGu0Uo85ekKXeSIXvo2ET2PF5Q3vqZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1142,"i_im_id":759,"i_name":"mPVqvyomHkvBWmtRgbM7FIB","i_price":13.5,"i_data":"YWh6jd7mkjrsY3CAZpfnjfdaPRqoghAVv1BpXuto"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1143,"i_im_id":8746,"i_name":"8WPZL576afA7S4nfw51qs3MF","i_price":26.86,"i_data":"zyLcAvoduQpfuEZKQcbF0MTmiM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1144,"i_im_id":3672,"i_name":"IlpAStDgUghswvc64","i_price":76.95,"i_data":"fOi2NAQ3uDhnhlvOkNlvwuSOjEn9mxlhVXAjytU9923Tkg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1145,"i_im_id":413,"i_name":"OiCrNbNSFu3BIcKr3HXuBZ","i_price":17.54,"i_data":"1SBvCvuPz2IIhq9sqQJRqq2afdd5mVzIWsBiip6o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1146,"i_im_id":9514,"i_name":"1udkwSOGXIcIO4odN4mpO","i_price":78.63,"i_data":"JEfjeQRUgGmvMIK9zpkCBy4ZPvVMujRz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1147,"i_im_id":4273,"i_name":"kFs7rTMsT9fBGk17K","i_price":71.11,"i_data":"FHiLuJzYga50BSTYyZlYVMug4BbZOtEajNosAB5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1148,"i_im_id":5857,"i_name":"Gr23IV925fKi7kGMEcHa0KbL","i_price":54.87,"i_data":"nscoPVHcIPhg6UshVcvK4kxFhGc7vDdTb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1149,"i_im_id":5149,"i_name":"19QoIfAcs7MvHq4HWLczL","i_price":9.93,"i_data":"ISRVFZDd4CIVZdT6BOxG3nZ4jVvIjEFp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1150,"i_im_id":1107,"i_name":"SkNbDal7HKaK5MzvRhLL","i_price":20.67,"i_data":"3AZzmS8TbEVnWHYF5YZbdjypi9uIFPWgky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1151,"i_im_id":3662,"i_name":"tvtglsqFLrIsvi","i_price":80.26,"i_data":"EgBF1uSk6HZ7PyoLtLW6BdpDbNoriginalXtTR9JX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1152,"i_im_id":464,"i_name":"X2A04y7BlJWKwj8af3ftIK","i_price":15.34,"i_data":"Pj3LNWfaSktq4phZE1Xsj1ZSjMKEQVGGsO1bYZ9sROMc7lp3k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1153,"i_im_id":3042,"i_name":"vDRO5wZLno5YpNuv","i_price":77.91,"i_data":"ybrGYgpD4Ww17iSidPyZSY68BWHBwJ5UyC3ctaBeRmK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1154,"i_im_id":965,"i_name":"PiGGeRPSYxRyw1NKij8r","i_price":11.52,"i_data":"mx2Hu32VHKfN5oZFoaHd9owzDH3HxP7sLtS1gQ7AMZNicSbpb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1155,"i_im_id":2503,"i_name":"guJje5wDM7bLBUIu","i_price":86.7,"i_data":"wO8SxJVsUtaj06yyUvr6TEILgCgXF1CHo8OSJzK5Rt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1156,"i_im_id":3797,"i_name":"i0JH6SycK19B2UM1V4bidJke","i_price":87.27,"i_data":"cGOY5SHaRCgD5sNdvXwCp6UVciaLrPdkIUBVLqgoGVBji2Bs3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1157,"i_im_id":9791,"i_name":"LsMfNe0WiYUttGIiGdAFSn","i_price":16.94,"i_data":"pladLMcNBmi1Ddp0AFzldEGQhkHeFz7f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1158,"i_im_id":5739,"i_name":"FmbNGWMfiYt5m2j7","i_price":70.77,"i_data":"Tjz9G9BnTyeNvFYuQsOhiETPdyddTAwk3ldhRmbjQHEHa0LYU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1159,"i_im_id":957,"i_name":"LMWoF7u9t7JbHbpCG","i_price":6.6,"i_data":"haIdrWMyfLfbauxzIEqLCLOzamztiQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1160,"i_im_id":3935,"i_name":"mCPMhEMo05eNLs","i_price":85.42,"i_data":"peDMzAAhGk8jpfGDd9ZVOObUuyqaM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1161,"i_im_id":3401,"i_name":"d6gBO8IeXWzefO","i_price":7.09,"i_data":"wbh2H6dZnVGJTfKxnCaXhweQ7SAvBcoW3naHu0wTiv2u6E5g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1162,"i_im_id":4685,"i_name":"UhrJHgGdYfdnan89C","i_price":11.34,"i_data":"JPcMLYdJ6lxuDG9SnI55eDl4khATGmchGsBG8XO5aKGq6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1163,"i_im_id":2847,"i_name":"ju5cyZOMHkCEBRQeEQ7LH1a","i_price":79.34,"i_data":"lphmshc2GHDhrLIPKCwKilIK9tFexRgR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1164,"i_im_id":673,"i_name":"A17AHiDCgIwKL1xMg","i_price":71.39,"i_data":"X8BavPVGSXC4Im4U4OJBOpHWdokcLM0kpEWT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1165,"i_im_id":3900,"i_name":"hB7peFFIHN7EvgQKc5qqHzz","i_price":57.44,"i_data":"YG9tnNTXS0efA3vMWBTV2T267hLVlrLNmgOSn6Kn1Q6b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1166,"i_im_id":8587,"i_name":"2dOuOvMzNa794mfXfab","i_price":95.62,"i_data":"iqeGu6pTDzbpn5oHcfb4x1nOs8AwIzAr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1167,"i_im_id":82,"i_name":"5DDF4nWRzaRVoP61rt5","i_price":97.13,"i_data":"8OSwt6ZlX7Vh48mKaVgOlRtfKOV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1168,"i_im_id":9011,"i_name":"38sP5pVGfceozKc","i_price":69.86,"i_data":"hrsO9mzB59w7qHg801kVKZ81UaaSLVx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1169,"i_im_id":7492,"i_name":"DjAAAbpSCSkZkt1962A4","i_price":48.24,"i_data":"bKJog6Y9I8tUwKZnYkvpJaazNOqGr5tMhI9IoS3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1170,"i_im_id":833,"i_name":"MxBWAB3VSB51xn5mi3HRn7","i_price":66.65,"i_data":"bFdkpRwVRwY5kxqWDmAFpCkZQQKTj7z73udusHDvw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1171,"i_im_id":5326,"i_name":"yDnENznEnLVzCGuoCOBHQG","i_price":81.52,"i_data":"zWyZUMPhEzCpF1vGD4Dc8UrrCE8Gl5g1xH6wp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1172,"i_im_id":1424,"i_name":"tW2FG2aHzlT2v8Jywkes3rt","i_price":86.06,"i_data":"KwdFb2hJyyHTLAjmOlvBklwga8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1173,"i_im_id":8356,"i_name":"MTkOZ0RKmTKD53v","i_price":92.39,"i_data":"8nveeFghtMFetTDZgkpgqoYFj4E1KtY1f3rOUrZzdG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1174,"i_im_id":5639,"i_name":"KqM4cCFOzeUnismzvfil","i_price":32.64,"i_data":"poriginalW3aOPWWYsiDdo5Uzwd8ecw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1175,"i_im_id":8266,"i_name":"NksJ8Ql4h0Ey9LKy1vG6xt","i_price":54.68,"i_data":"zUfCw3S6mH2xCHiJZYxiXamEazE9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1176,"i_im_id":9454,"i_name":"U95gD5JVf5JEeGkmLczY","i_price":34.42,"i_data":"1NRjex31BwAsZ8KYfbMEqxH06ygF6SJYI7qJ7XW6FY645"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1177,"i_im_id":7894,"i_name":"AcouBSuAPwcncQmAs62YJ40I","i_price":94.18,"i_data":"Pe7aQMlYoZUllQF7Sm3xNqizeGSWUTO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1178,"i_im_id":1939,"i_name":"SZ9Qux4zKykbLUFJKk6Bi1nB","i_price":77.6,"i_data":"YwNbTr4QWazHmUFUskV6VixXi6sOxzVX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1179,"i_im_id":3847,"i_name":"r6PPkA8fr6WSvi7A","i_price":57.55,"i_data":"BTwqXXxXJHDdADQVw9SJiVHsrujUm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1180,"i_im_id":7782,"i_name":"Cw8yMBd6tgk8WlZc","i_price":28.8,"i_data":"5GYsX59sa8UWiPD4031pN32XhQS3ziK9lsNSZcKOx5iB9MLp6Y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1181,"i_im_id":6408,"i_name":"SLfsxEDW5U3bQedV34KRyQ","i_price":86.24,"i_data":"aYLZkcp1CPYT8ejQN7VWp4ypfmq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1182,"i_im_id":256,"i_name":"4eztr0l7XpAJDtRlHq","i_price":70.69,"i_data":"RcRzAksEewVWZXROFHWMoHdFdxA2b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1183,"i_im_id":1455,"i_name":"q04Ybp9gtmpT8RXwiKxqszj","i_price":52.08,"i_data":"FjG5DumzykyLlgtM5aKztkGXbsLbdnz7x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1184,"i_im_id":8694,"i_name":"wuhoaNNXiUcmQu8MfvkZpj","i_price":20.94,"i_data":"HFSk5KVs9lv1K4xEHMpQ5NQQz3PiXh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1185,"i_im_id":5568,"i_name":"GvkTMzGc4svwCmYaMIeJFDE","i_price":59.62,"i_data":"iLQkBAK7lS1zrEmXdctdNmYF4G6rJXACW2FKKsdds"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1186,"i_im_id":4602,"i_name":"XZmUOY21cmp6Rh","i_price":52.91,"i_data":"E2Xp0ZPpW8q26UK6Ik7gxvdtugBl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1187,"i_im_id":6425,"i_name":"6ESn3imNefey3XCV8HBp0sn","i_price":22.18,"i_data":"bzEfBcHqnTGMKHnuqhGBnrf2fTu2ccwJKhMIaB3CX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1188,"i_im_id":5933,"i_name":"LFzgAjXqOnjPECBcnkQ2WMY","i_price":83.19,"i_data":"DDAIVV88aVzW0RvMqoguPtw1J6g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1189,"i_im_id":3241,"i_name":"oSXPqILMtxwLj5","i_price":14.5,"i_data":"ES3yjz6bUkhovQP2lutVGtEYIaJp1nEAeztLcTiB2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1190,"i_im_id":7935,"i_name":"Tc8NKhKKj8xUfoDOqX1","i_price":49.57,"i_data":"40HrMwvWphBPJ2SJkm8n70pN8i36ouO8jwEfsWl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1191,"i_im_id":8077,"i_name":"8bjFh06Rcf6Eg0SA5QWqL3","i_price":3.36,"i_data":"zz3q8kdHcKW4VgluQZ4p37egJo31XA7zRPa5m1yrwRMBfuV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1192,"i_im_id":6234,"i_name":"XcxPdaojEtO4iUldHI","i_price":41.19,"i_data":"nEuNSn0gPMqWtwEtOrMZWiAwrXUVq7FJgJl5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1193,"i_im_id":3888,"i_name":"6ex3KLAokE11KoXstCy","i_price":72.98,"i_data":"avVrIh20CIz9fCuBrgo02XGV74SPohkyRQxnSPG6boQmSiZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1194,"i_im_id":4106,"i_name":"YE6D4n4J7ajBLQyp0eA","i_price":24.51,"i_data":"211bOXeESEDFtrn8Koriginal1gkUvlxzXzKzJkn9oD1k9fS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1195,"i_im_id":8015,"i_name":"cai0tg9EbojcgUSntIJ","i_price":58.26,"i_data":"vziMT7XQdMZjI12oHOoeU8XL1emofMYK0jfatbm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1196,"i_im_id":8977,"i_name":"Yf1ei6thDJWBkai2E09nl","i_price":45.68,"i_data":"tR3Lr32LBO3ISqHcqVRYgRAlxu78vfueQNMK2TGT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1197,"i_im_id":4104,"i_name":"bm1J81ixcngRDKP","i_price":76.78,"i_data":"lY8SEiy9kVCZHMqZlIKgPFErb4MgpWLeOzYVloZQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1198,"i_im_id":3956,"i_name":"b8n7j410XuVh28CWuoMSeOt3","i_price":48.37,"i_data":"mhIepGeLaQeXNtIe3juzxZbECpBNjtJfbH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1199,"i_im_id":2407,"i_name":"WS4CBFMmzH7zafR6","i_price":35.13,"i_data":"VhtnYZmFaPxpyG3HAed3fj1ibzSROfHjLV46iH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1200,"i_im_id":5975,"i_name":"OfufPCtBRzzdmmqYFUA3I0","i_price":18.01,"i_data":"G8y8QugatVAcN5WqpScD4f0alRf6TyGCxUKwmgWlz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1201,"i_im_id":2915,"i_name":"aUADZmMjgFUxAkrHFx4bfRWZ","i_price":84.55,"i_data":"2Cd9pGhFppTCpe8Vm4vwSyHr0PmYZnblRUV9HMr85"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1202,"i_im_id":9531,"i_name":"IooWqqNfBWfVFfo","i_price":63.98,"i_data":"QXKaCp3AWYi4UdKtpF5qSAr70zbKsLCDE2IpK6etz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1203,"i_im_id":342,"i_name":"msUeoyhGzGbFU41P2N4c","i_price":94.7,"i_data":"kO8K4GNOP1jrOihlzbTfRgsNWiXOexKiNkEgf8q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1204,"i_im_id":5874,"i_name":"t4Zc06ibr46rnUo","i_price":38.2,"i_data":"XKBVky5bxDNQ25XDN1hk9HwUPgo3MSNdR0cpiOG1BLdO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1205,"i_im_id":7926,"i_name":"II98dtbPbqzVQFbJj","i_price":59.96,"i_data":"rjDXrvrbjsBV3zbbGRgQBpYw8jKikjqvBcEpUIq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1206,"i_im_id":1025,"i_name":"BracujQqozBU4B02w7Q","i_price":43.38,"i_data":"V1tsH1kl3iZ8jB4hdlyr7ZIZHiV7PRQqO71f5d8brjuFIEeLTF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1207,"i_im_id":3446,"i_name":"J51yrkq2EbzrDWKF5F2","i_price":57.72,"i_data":"Oaq1MUiH0FVQbaoXgRpwqcdkerXTEmVGcGLWperKUCDxXwmEW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1208,"i_im_id":1289,"i_name":"Tzv1YxMu70cdYA9pWWR","i_price":76.14,"i_data":"bI4SG7W3cOzQ1zlymbcHpTJ7alIjopXZqp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1209,"i_im_id":6186,"i_name":"fXqxhjhiqpioGKN","i_price":99.44,"i_data":"XFCG1jK1JxFelOxJnWZKwN9uOW0jp5tqhp9gzw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1210,"i_im_id":5503,"i_name":"JWTxmZmnbdkdKMXpUh","i_price":93.54,"i_data":"8p7ijC9wIYWQuaSUK72Bt4vdXN3hSnk6XJQOciGvsGzgQUeEiY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1211,"i_im_id":429,"i_name":"yX6T4dG06qhQZ6Otyjb","i_price":14.11,"i_data":"6NcxacYn8VJCITwmKeWZnyhpZKP3BSb1V5OxHhaK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1212,"i_im_id":9701,"i_name":"smXsoV5mxxJyxo8","i_price":45.78,"i_data":"bMmfNw1eRydRbCfm0tskgN7qEr46mCPyI5fOuvuSrlcrO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1213,"i_im_id":6979,"i_name":"WO8wMOEq5E7AAbVrAaAS","i_price":73.13,"i_data":"5zj6F0ygTqMA62en8DmIJLIHXW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1214,"i_im_id":5713,"i_name":"fNj0gPW9u1tKetV4XyO","i_price":72.18,"i_data":"U5r6cr6GozgLJNca9iFPlqA2U5JtVG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1215,"i_im_id":3370,"i_name":"RSYuy2llNNGOftOERZ1","i_price":84.41,"i_data":"V76ts5GOk6KNw6MF3hTN0R0KzkFRxoGPn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1216,"i_im_id":8451,"i_name":"DNQ5jyUkyI7Vpx74fSzyk6F","i_price":82.3,"i_data":"0Y1a9TBBPjRiIfEcCD1lRxf3Rf5JU7RbjQo0HC8vfz9u1h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1217,"i_im_id":741,"i_name":"B5dTiQWK4iABJuDQ","i_price":95.69,"i_data":"gYDyy5FHG4yXCp0z4WrQKwAmlj14A5fi5quOjQeLuhRpNl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1218,"i_im_id":998,"i_name":"p2rOb9TRfrpmEB734J3K","i_price":12.58,"i_data":"4oUB1BzDWZb5w1g5N1qrVZdBQKjfCAlzz2dqVV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1219,"i_im_id":6777,"i_name":"2wzqCCkL8gUkRWc1k","i_price":77.59,"i_data":"NdNUS2QRfVfm9Bhl05jqIixQXIJTVi6XSPPJ3a9b1i3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1220,"i_im_id":4303,"i_name":"Ru8hSBqNF1LjhI","i_price":4.2,"i_data":"pIQ3j5piTw2Ntwu00FxddddxZ9dLjvMyJrI0Zq1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1221,"i_im_id":8565,"i_name":"ZybIvbbugXyNBR","i_price":40.42,"i_data":"ZqfyeU93kn0kSdthAvEmvRvSBCwOHL57EBgRn4g6wMU4N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1222,"i_im_id":587,"i_name":"onKlpy2g8wCx2Zy","i_price":66.6,"i_data":"c2whRgKGoriginalkLg0DhmBiWsCXDVKKEgFIYswPh2s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1223,"i_im_id":9274,"i_name":"VqwoQjSGqOHG5idIYuku4","i_price":97.07,"i_data":"WuErwsj13XmUohYQmz61vn2OmxZDzgnwkNWeZiyf4rfwkH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1224,"i_im_id":3071,"i_name":"dhjVtCO2GdYxYE35LjnO","i_price":90.09,"i_data":"aPkprm6w2YxRTLDmjdyEWKdgYC8FTCVVcME47DoHONxA4o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1225,"i_im_id":15,"i_name":"YTJkVAj41wIrXL9SD1S1K","i_price":17.34,"i_data":"P3rdXs1aKiJ4I7euUne4muSzYzm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1226,"i_im_id":4210,"i_name":"GCrpuIkldMx9zavdwBqX","i_price":86.79,"i_data":"QILsFziqzRQ09smn8Ca4BcES4bPo8ifqG744rI3HZb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1227,"i_im_id":6959,"i_name":"epbF3M9VM4IlxGY","i_price":83.7,"i_data":"Ci3tnxGexPJ8RbJxmuBWUk0ZtiVoinCKNNOPG53f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1228,"i_im_id":1476,"i_name":"YEKkcr4tQDDK9nobDwz","i_price":1.09,"i_data":"749kENktscsKMQZAOVxPtgrGahrTxSJ3X4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1229,"i_im_id":3688,"i_name":"YIJCQvkB9WHJ4DiAfPmkF","i_price":35.26,"i_data":"7nR8MuitNucp7OH9kaNZtsZdScHe5Dg9hh2tCm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1230,"i_im_id":2489,"i_name":"nuStI9F3F0w686CyEPF","i_price":76.39,"i_data":"EM8L5XpnQkcsod2glRFzvmj3YGQxm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1231,"i_im_id":166,"i_name":"qJ29mh3igLo8PL95KNtLf","i_price":25.19,"i_data":"lt1KdpOS6h1GrteWkkT6nXoTz3itJL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1232,"i_im_id":4588,"i_name":"tENXvTd895E0pd2F2","i_price":23.77,"i_data":"EjTn5RDPxUgOx8CFuLmAgFxaZHy6ovlDxrUlBhBCshK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1233,"i_im_id":6292,"i_name":"VZaSPnxSH6mvOSuvJU","i_price":74.94,"i_data":"9gv61UhkaQlGR3ke4vRLDN4JihzyGIk3s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1234,"i_im_id":7779,"i_name":"VKIGIcNtliDEQTiT","i_price":46.27,"i_data":"60Yc8YacS4RNCRnnNAzvLl9CG1y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1235,"i_im_id":4843,"i_name":"J8raIctBuVtr32tBfUW","i_price":40.68,"i_data":"529KBX2Vq1GDBOEZvhhsC4Wy8wutL6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1236,"i_im_id":688,"i_name":"LAtzLcslJibFrX7PGdt","i_price":87.19,"i_data":"Wyqa5uu3lMRsCM8vLxCR5UYmOgb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1237,"i_im_id":9384,"i_name":"4Ha2KoPaQqAFuoPY","i_price":38.81,"i_data":"fd0dk5taURuMqGNnGFhFiMruMGgBzaH5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1238,"i_im_id":274,"i_name":"oocJRss86l5uIOqT8BbpokD","i_price":11.27,"i_data":"LHvvvAfGi8gOA8OUHqROc6vNXDAB4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1239,"i_im_id":7823,"i_name":"0uunc2fQ8ungFUMGXSI2XiRr","i_price":45.54,"i_data":"MoQ0j5UdBDfcOEW2eh50m7PL73"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1240,"i_im_id":8118,"i_name":"vJKBFA2R0yKwcVYa6i6","i_price":30.69,"i_data":"KrMgFOyWL7IqyaIzFrHvURnx6aAol68jGueRD5QPgNf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1241,"i_im_id":9235,"i_name":"essawDgvkdN8OytblGOOAHX","i_price":97.32,"i_data":"E4iXrs0c6ERx4CkSd3bcZJk9NZXrHCKIEVDwYGRTb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1242,"i_im_id":7453,"i_name":"swZiMOVaMB8L6DS4","i_price":6.44,"i_data":"MS1Tdi1acAy6Ea82u1mxtYaJ3fI8i1cdCwWssMQ0TK9qUnfyPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1243,"i_im_id":4038,"i_name":"AAaEXNeuplOBwpu56e","i_price":48.32,"i_data":"1frfwv6KVAyCL1n3xLCjd6uw5H2TWsFbZ1E0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1244,"i_im_id":4175,"i_name":"KtEU2TH6ux1G6gqDIDI","i_price":91.35,"i_data":"t9ZRSHJ1YmZOZCiDPwMgRTz0zJ2ZgfrxyBuRCjiiM0wH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1245,"i_im_id":4780,"i_name":"a0I1a1RFf4zLH1D","i_price":48.26,"i_data":"YAMgNTtOv4ECDQH5QeqxpgAD1koriginalSfKLtb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1246,"i_im_id":1987,"i_name":"WcluqyDt8cxKZjfDWrSocMpm","i_price":84.96,"i_data":"l32BUkQLOOISmzVjZgr3lBeEeSWQEqfk4FnTf5pZxjkjoxag"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1247,"i_im_id":8279,"i_name":"zynrGW9lxFY417","i_price":76.27,"i_data":"vGSC3EervhSrUZ449BdoO4kbxL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1248,"i_im_id":3230,"i_name":"qR7Lk6AUzS8k3U9kyfV3","i_price":56.42,"i_data":"husksLR7R8r50rXq9B9KyPkANQOZGqc9tTu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1249,"i_im_id":2404,"i_name":"ChpXXVI7HTKrQyzhWVYo","i_price":74.59,"i_data":"54zJwIKi5VmzxUyrDhdqaqcOW8c6tCtEk2cXw0acHw5uRazQoF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1250,"i_im_id":8123,"i_name":"Wfp1En3Q4TWCgCEHwVp","i_price":90.93,"i_data":"FcNM8V2VTFcbbCzyurrebsFMUmUbbAoOLWjV10s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1251,"i_im_id":9522,"i_name":"e9g9AVNUrKNhRRtHfqBGtnLN","i_price":52.17,"i_data":"nxywo7CwlK8xfA6C6QEvuW05VrWH9dJtRwJj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1252,"i_im_id":3819,"i_name":"FyiDfYOp0Wo1dJ9","i_price":75.49,"i_data":"QDTBVWtbkEEj46vbBBz522vMCb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1253,"i_im_id":243,"i_name":"UIuTDjzpNPrh6nwqrG","i_price":26.31,"i_data":"HabAkUx0sjQqcbJLNqLLn2zFOUkw2dBdgqGUoxZIBCXSyU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1254,"i_im_id":1307,"i_name":"eADG98VOOEdQwx","i_price":6.41,"i_data":"KMENrBDQmdWsLz5avRsZGtMCmfMJZCO2ToriginalDdb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1255,"i_im_id":1916,"i_name":"RXill3VFEZ8EqjWjt6fGUiP","i_price":45.82,"i_data":"XllLtzogwJh0iTgmzBfgDbS8QwGIDTrnR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1256,"i_im_id":9964,"i_name":"bAbnWECURh65qStcK5v","i_price":22.28,"i_data":"DMrlujyO6meG9C2iZpdbDsghbiHuIoX05SniQY7o4SI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1257,"i_im_id":3008,"i_name":"jRfkpxXnTRuyWTe6z4qVd4dl","i_price":35.43,"i_data":"hTEC6MG0dIgk7sp9LSQJgJRJZJYEuqZyo05qAPrkRcb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1258,"i_im_id":2769,"i_name":"9mEPJpH5dGBkggzfOtzdyO","i_price":67.11,"i_data":"Qwk1fGKMvW8I1bd6FPOW0VqJMjTd66"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1259,"i_im_id":4975,"i_name":"i3uMfHMSYlwlRdAqYHJOB","i_price":26.39,"i_data":"Jh1XtfzKEme5vcT45NsEkdbFRECCEMwMTgeT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1260,"i_im_id":7320,"i_name":"ofkxBHZUOGAPOxTYDP","i_price":25.68,"i_data":"who2qBM5cTUU8WqXPEkHCBloriginalivrF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1261,"i_im_id":3165,"i_name":"2VZmD79KsjictWK74GGwjeS","i_price":45.13,"i_data":"9dbUWwgT9Yiz2AwQXfwmz82kWqdTJNZdOKYRaeWe5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1262,"i_im_id":9895,"i_name":"g5zRx3qwv4QOu68c1AFQFuIc","i_price":99.61,"i_data":"MxqRuTxzCtf7epQAYAKmrVBpK5X0PHWxsN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1263,"i_im_id":6438,"i_name":"U8XmpPbUnZwwtbJuCwa","i_price":22.35,"i_data":"GR7OYoriginala3fBMdr6ajgMMOaFtxEK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739205,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1264,"i_im_id":7895,"i_name":"vV5NVSEt9iybQaQxI","i_price":7.9,"i_data":"82HaLnfrAiGRsav1DE97vEodKRQbZPkG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1265,"i_im_id":7919,"i_name":"yJqU1OETNzihkL","i_price":44.5,"i_data":"qtDgOycrOYNPsacjHq3LThrvnq0a0UJ1nbpb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1266,"i_im_id":116,"i_name":"nPQ9MXF7AQQtfGHGLm8i81","i_price":97.31,"i_data":"MO7llraknYgiFDoHoxO1OWPcSWflf2d29UR1Gz5mJkgL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1267,"i_im_id":8739,"i_name":"8kp3b7GuUtUKIXBSBoc1PVV","i_price":77.25,"i_data":"6nel9Eriuj3oBMPJKD6itWnj2T"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1268,"i_im_id":7753,"i_name":"18JkL67LfysPmMAyGy4AQUj","i_price":36.98,"i_data":"ln3jjbanlxzNvGjsVcx7SBYqOnb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1269,"i_im_id":690,"i_name":"BLxHyPe5wEuBL8e","i_price":71.12,"i_data":"2TvZ495HDv5hNqdoPtq1kzTVH4FM11axsdinELH2N5OJNwCV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1270,"i_im_id":8606,"i_name":"v1KMfS6cpybDLxhNptHl3g1","i_price":51.97,"i_data":"3c871zdXGPZzu3iZNL9qwNregbaNC8TNz52uFAWEAKw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1271,"i_im_id":8673,"i_name":"01uXuK6OZMODiUhZYqZ","i_price":75.52,"i_data":"HpHqhDj624oUl0w50sZ8O5vyKTrXfWZiCEF3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1272,"i_im_id":6466,"i_name":"d63n3xCzy9nbQk2x","i_price":6.43,"i_data":"XnEt4XdKFYmO6YcjFeJqOdgSAknYVUipPZOIU0qk5jqWoR7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1273,"i_im_id":7185,"i_name":"sj4tIRIyyn3es0jDtk8qF","i_price":67.79,"i_data":"4wOKb1bG6ggyHa2E5xui8htwA12iDQ7xyxsk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1274,"i_im_id":4626,"i_name":"48e7v4yeun7nkKCn","i_price":30.81,"i_data":"CG8zlAvVwoIsszgSj4nAJngKFfJaYINom4Pe83nJbqpSK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1275,"i_im_id":1290,"i_name":"U49mC5p75BYblY0l5SxBI","i_price":87.32,"i_data":"Fy4zDn6TktyIyAq0Xvk7Ycm6w29Jg0P3ZYkCDhPeu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1276,"i_im_id":5176,"i_name":"KIgwUY0g111nbhN","i_price":32.55,"i_data":"MEMjGSL007j7Le4Oo0xnvZYjDEce9XATRClhW5A0YupYgaHv9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1277,"i_im_id":2145,"i_name":"KHSWUvfX1zoEhPKsZ","i_price":32.12,"i_data":"yoZMuhsTnsWvYYpM8dr2mrkkf9tHR3iPFRzITepxJSpnaKn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1278,"i_im_id":6785,"i_name":"2GLER9h3QY2bhbdA6CK36LyJ","i_price":10.46,"i_data":"fm1UBC9fXvPJPXd7YLMi46sqhQD6j4tfiFM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1279,"i_im_id":476,"i_name":"4mgFAjtvriX1JNk7rnJ98rn1","i_price":60.89,"i_data":"PCXiiLF2MZ7BvPg3WZx7NEftBZX8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1280,"i_im_id":3267,"i_name":"A8ZECWjx3AM21K6hc","i_price":75.36,"i_data":"806txYbgRdj4adRiZmv6fbWL6C0ZgkmIcn7ofSKLQzeXXgBuXX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1281,"i_im_id":6396,"i_name":"3U8AzCOwfjgS4RHumu8do","i_price":10.93,"i_data":"VKfd2IqSi5WKpZR9hIoO259pDfUgXeS4KSLtGN4PUCdjRiegvi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1282,"i_im_id":3016,"i_name":"t9lCi4dHew3BymRzyNy8nA9K","i_price":69.27,"i_data":"scPvFPGoriginalUW3UVyNzg8R9gtHXvAmAaeWNrpXZKTGR3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1283,"i_im_id":3612,"i_name":"ZqpxhD6b9RDKMD2EOx","i_price":3.87,"i_data":"2ndV68oeGaI3I1dE20WuJjc72KQlAledBilMeO6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1284,"i_im_id":8948,"i_name":"LP2IilM1Bhb6G0bzkQJ","i_price":35.81,"i_data":"sb18B44CuymyjwQPwlgHBQWS43R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1285,"i_im_id":5297,"i_name":"0z7olVfNXWNXfhG8OEGWt","i_price":17.04,"i_data":"5sQP8T2e8KjVnSRTwhjgNTqUOCiEmqi6yxRsg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1286,"i_im_id":1945,"i_name":"ofOxLC6d6EzopbXCUBC","i_price":22.95,"i_data":"hxO6DXJUMstph1248GY2k8RHZyGMzweD8wwjCsb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1287,"i_im_id":6387,"i_name":"3eqa267X8jU6om5GHMiTI","i_price":90.4,"i_data":"V6jmYfrcLD4h9TOHWgsbgPRlZyf8NcAObPILUUUdqkwHXZRV2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1288,"i_im_id":6717,"i_name":"2bVqfwvKbtvpvS9lvokZOaQP","i_price":6.81,"i_data":"8N4XBoriginalcRnsBUmL0qyWKpQRcPj2n"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1289,"i_im_id":4234,"i_name":"914oNpnwBAXXOFocdb0","i_price":67.25,"i_data":"f4pd0IIJ2s7q2ZLLS0xU5VAbNMT14c4ZLwhlCHHHPbCanSeFwR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1290,"i_im_id":5985,"i_name":"gPahrTSE52dMgk","i_price":89.98,"i_data":"vssJDuBc4QIgwqlB5IWmNCtveaaaqB0YYPlrsadVywvxc1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1291,"i_im_id":3694,"i_name":"oYBlXuJnf0AhIT","i_price":86.71,"i_data":"otrltnrppMGjep3KGz12PY9ux3T8ocIK42kd1gj1u1sfif"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1292,"i_im_id":2966,"i_name":"3nvXvTE6JQ5z80cak3oRX","i_price":93.68,"i_data":"Y4VBR3BTLGGoriginalg35r2AVR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1293,"i_im_id":5366,"i_name":"My7wIbRAEvJNOpXkOFmKf","i_price":9.29,"i_data":"euIVVLPLRyCyvZQSOOoGn0NpFykyKpPbb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1294,"i_im_id":8581,"i_name":"eNUw7B7Qryvi1fQSkQVB3vZ","i_price":19.4,"i_data":"JRoJ042qcwSqFDzb7lMoMBRZECLdpisv0c9JRN708qE9uNs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1295,"i_im_id":3485,"i_name":"kNEHkVKYtB1oBFDfyN","i_price":26.54,"i_data":"qN7dZRCzaQW2jhWfbuUguxMGNFEcZkm9nOGyVPtwJrUkaXXFg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1296,"i_im_id":7354,"i_name":"zNRXf8lbdh1mSGU9mV4L","i_price":18.76,"i_data":"QtyuD3lGMGp9jHyZnqfCV7uZAnaEK1hw0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1297,"i_im_id":8316,"i_name":"7PxurGSq8yDvt7c","i_price":68.24,"i_data":"woriginalnuldxJ6gcCk4A8cJelowemkvKzpVFq3bUcuhrsj0b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1298,"i_im_id":2297,"i_name":"0FljyS8XJP6gHLwEgJmQY2c","i_price":6.45,"i_data":"IxGbcLxrvOU9Md1HAQkrT43Abswp9ZBLydSLq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1299,"i_im_id":8916,"i_name":"B6ms9OTDMi3eRAl9f","i_price":55.19,"i_data":"HOFgzCkVfZE7fob30pptxO3PHyhfjICBz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1300,"i_im_id":4270,"i_name":"Ew7o4OjmhL2dtIAw1yutOk8D","i_price":48.81,"i_data":"g3hfRfOZQ6yVKIMgIlxprIwJbzdi10UOHlbJjzGvmcmGx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1301,"i_im_id":3333,"i_name":"cg3qrHbpImojf6nFb4","i_price":80.83,"i_data":"Y5kXyfWo65TzkIJoUe0mr2hEW1oo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1302,"i_im_id":9109,"i_name":"7fbmxdUnxIol0avVYxR","i_price":84.85,"i_data":"Mn5nXXBcmWAqy4ONg0t8f4O3QfyFbnQLB7POdT8uuofA99"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1303,"i_im_id":6540,"i_name":"jPnDlPtfM7Z9xUbcQK5GUt78","i_price":66.22,"i_data":"eTlP094Gp8FgoT0P5RJW4e1VSYsow4mCFQ8JlK7q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1304,"i_im_id":1465,"i_name":"TH4UpKUwsroSrOxi","i_price":92.58,"i_data":"ORGuIAFlXOfxLoEIMiEk5u72tW8MKtCTkRcP1qjmM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1305,"i_im_id":5514,"i_name":"6hejCEJaJ1FLkHacbfdN0BZ","i_price":37.17,"i_data":"seZ0R4Sl8aQBiCalAhyrrGOYz8ZNj2Jd32"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1306,"i_im_id":2286,"i_name":"gtwRabCr9rVx81MngNIgain","i_price":61.94,"i_data":"h1PqD8bKDTrfwGb1VuDaDmKdDb3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1307,"i_im_id":1082,"i_name":"qaf7t83OBruktJ9","i_price":20.49,"i_data":"7QH58XMwDurLwSc9iM0sRx8oAhzv6rKfkIbDhK2PORB2uSWy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1308,"i_im_id":3903,"i_name":"QPxvlmw1it4mQzt","i_price":21.56,"i_data":"G0YBpOTcK5ZJVdHd6JiUtVZ5pLS5ZXr4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1309,"i_im_id":622,"i_name":"wCJO9G1gWMaw1NO","i_price":14.36,"i_data":"Y02bnees1wgkgqoriginal3QFG8pEA7spvCS14RrMT4WTTKi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1310,"i_im_id":156,"i_name":"kMO7WlpELX1L3V","i_price":64.48,"i_data":"fIiCEOfKpG3KCCrjTv4k9uFTr5TKSJX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1311,"i_im_id":2600,"i_name":"0TmKzqDa4k4jLjEQgm8VD24","i_price":58.62,"i_data":"Bg2ObKGzSOzrkhx9yhtnOLQ0Jn0O"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1312,"i_im_id":345,"i_name":"NkydGDsNDYVNwoiOt8Yeky","i_price":15.78,"i_data":"UEGQCc54PwYLSFidYbhBMcU5qIfM9o5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1313,"i_im_id":8526,"i_name":"JaaAXHlv6215ojmszfUpCtn","i_price":94.7,"i_data":"22ogzhfgkLpOTNfIZ9TCbPORY1DKndrLl30BxIFUz5OV6V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1314,"i_im_id":5428,"i_name":"7xAnW0EwRHp4GR","i_price":43.16,"i_data":"DdLjaRmyIhhJF5Ns5dzfUSj4IMoriginalPh0MURd0H5k8j2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1315,"i_im_id":3881,"i_name":"lag6rsYOXDcrxxdYq8k","i_price":57.6,"i_data":"I9sT50ceBe3K3Kh8RUyt45iycd8Vy6yrL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1316,"i_im_id":5873,"i_name":"zxMHyXniVBNuJHq1qBSv","i_price":50.15,"i_data":"OYJm4for9SqrQgRaPOflbq8j5InYKUvBXWD79rGd8j"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1317,"i_im_id":9239,"i_name":"CBjTJV2FR9ssRFWFxg","i_price":46.35,"i_data":"uWykFxWtomUlIwyCS4wTjy8KOI2nPaauzReIHKy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1318,"i_im_id":4837,"i_name":"oCges9emvR1NY4J","i_price":8.0,"i_data":"TnXhUPyg97fjc8eh2WLQEfWfLWJYuXpJgUO2l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1319,"i_im_id":6370,"i_name":"3DcnWpHFzCuyMu","i_price":7.98,"i_data":"IzB6S00originaliY7roXkL7Y0DPYAh5XSeIFx8glZS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1320,"i_im_id":5543,"i_name":"QkoYhRYWtcIxrAlYG","i_price":53.02,"i_data":"SrOkSR17QGuc7Ujwx1aXssvmLh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1321,"i_im_id":8727,"i_name":"eWdLHgE1dcx5pPJt","i_price":9.86,"i_data":"5mcgVg50qw12TkYjj0JyOimCuhc1RO53V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1322,"i_im_id":1311,"i_name":"evhqR1IxBQPNjGud9","i_price":77.2,"i_data":"EK0MwTao7xsLrtv2DumndjVlBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1323,"i_im_id":5279,"i_name":"joYF1D2gx4aZDJL","i_price":98.47,"i_data":"Letq21mrksUQwJ7fa3NjN7riPp24fxXiqOPmBUb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1324,"i_im_id":1384,"i_name":"U3LubhEKNJKV3J4BMGLCB","i_price":61.88,"i_data":"YaKxK9cXUKaGxCYBUbpEwLTsT9IOMlZKrApS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1325,"i_im_id":8823,"i_name":"OlqD4h1xsEkkcZbbu","i_price":57.32,"i_data":"vI7hrWjcA4pyOKuZIfnKWQYw19FliNlZQVvM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1326,"i_im_id":4219,"i_name":"x7yR4WekD59VLb","i_price":13.13,"i_data":"dHm2AmBTPrjxqcYBkrtDYg5hLTjqzEFeWMvsUKy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1327,"i_im_id":1215,"i_name":"EW6wexpJd1gmIce","i_price":31.22,"i_data":"sjk1Qu2P8iYzscVDVozoriginalixGZU2NOmhMxlvh7jUT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1328,"i_im_id":8230,"i_name":"FPZexJxJ29Sk5TOWLb","i_price":16.7,"i_data":"lnI2CmWjsVWL7OpxMsVHQOogOnCRtN4nW4DkuZbdC3iyReW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1329,"i_im_id":7763,"i_name":"TEQOQFcsU6yhrUldJFj5RdSL","i_price":53.71,"i_data":"99KZqN70w09LqxpCTwMM1e5UV0b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1330,"i_im_id":9663,"i_name":"KvZ0CwcvxG21Sc","i_price":37.07,"i_data":"CCxp3dtaIIegqloGp1HPJZIiHv0QIz6GEqXbhJe746"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1331,"i_im_id":2435,"i_name":"XNpnuJkXkBLHYS6","i_price":60.53,"i_data":"AyWx1qr6CeRFUvMiDuZ2dTLBKs8xXb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1332,"i_im_id":4082,"i_name":"hA1lXHgPGbLKcS0XG","i_price":51.97,"i_data":"oPFQbrIByLtzsFSt4S1ztm2LGUUoBb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1333,"i_im_id":6855,"i_name":"Zk8hs8cvh7FKmO","i_price":68.11,"i_data":"l8bgh6tAxRrtuzrv4IZYTgiombdprxRV0R3NFxflhmRPv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1334,"i_im_id":2040,"i_name":"iwcT93ufn2B7M5","i_price":35.24,"i_data":"originaloMnyy6qd7IRskwjkeELEy9yU3l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1335,"i_im_id":714,"i_name":"Z0BRxLp0y6yUPtwD9U","i_price":72.53,"i_data":"5JQhcThb3t5ZmTJspnru3zh3naOiXwgtUtTRrMVU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1336,"i_im_id":5230,"i_name":"mt6pXBdIqwDKSnADdA4B","i_price":44.73,"i_data":"rEX7KQqkjXiZQnTGOBW6zP2IsOEzVRxs0a9XvnDbb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1337,"i_im_id":9290,"i_name":"3Uk21kVmjqfgu1Upyo6UV","i_price":86.1,"i_data":"dLYobjH83QAtvwaTKiGk1HstDmUyLA2W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1338,"i_im_id":553,"i_name":"9awoVwqe8FEcgJQfFJ","i_price":71.27,"i_data":"FkYUZN2XejKuaDDnn5lb6avNKO3lkgxk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1339,"i_im_id":7142,"i_name":"uKFdauo3vYlBiM2CsUwTv","i_price":44.53,"i_data":"UBMzr2Fr4p2CU4e58QxeQ9ff88wbB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1340,"i_im_id":5852,"i_name":"MCKikjTvGD6rEIIKuLONqq","i_price":76.6,"i_data":"GV0wkfUV3WHjl9bVTPaqSQJnHwxI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1341,"i_im_id":8855,"i_name":"b1EohMuu3RFu0ODf","i_price":60.11,"i_data":"7D0Y56UBKpxgJ4RLDd3Y6zDfmgC2tvPxujBxad0xZkZaLGLey"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1342,"i_im_id":5084,"i_name":"cHEKcUfelRkA1x","i_price":87.56,"i_data":"2a2lTY2rlq7eUV8IHMlhzSpDeVHBvRb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1343,"i_im_id":5447,"i_name":"olS5kG6EPR4IZ53q7","i_price":96.7,"i_data":"BcFNQ0k8SDGBcKNmD17yRViUBUzqQIBIGc7ujAY9zxQ9PJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1344,"i_im_id":9426,"i_name":"acdVTPFnqogRx9gikMWsB","i_price":55.89,"i_data":"8jH1eUrS7SqFmL7O3FL3nlGM9V4wdXLteitfOzhxEL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1345,"i_im_id":1938,"i_name":"ccyBivg6Og74uT","i_price":98.23,"i_data":"qQO0YRUb3VoriginalrApBpBu0fuPc9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1346,"i_im_id":7887,"i_name":"OW1MtAVyNmiwmIeM8Ru","i_price":48.61,"i_data":"PXlYjr1U741z7tEybNwbXOMRrEzoS5lJOrkY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1347,"i_im_id":3940,"i_name":"zUG8qz5tVC5vTWgup","i_price":96.19,"i_data":"uRL6Nm4ixizk9U5FoiVBo5eGfHTGEfYOuc5hmnqW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1348,"i_im_id":6101,"i_name":"MKPdSLF3cFvP92N","i_price":86.39,"i_data":"CwWpbTGKzJcrdejtCln39WuSk0XPRaw5eu6atrA2hYOygT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1349,"i_im_id":3299,"i_name":"O0cGuNyxio4wwvIW8v","i_price":34.3,"i_data":"XtIYu7Swko5fVRIkN0ClNZlWqAhR9bVCxtD84eIOzm5M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1350,"i_im_id":3183,"i_name":"tKeRiqmX72izEGY5Tpkxj","i_price":92.34,"i_data":"KXBhVcRdFtQoGpXQL61Sk0187OYltQgNypTKC5DD03o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1351,"i_im_id":1033,"i_name":"7038A20mvPMdL0Tdg6YBo","i_price":94.13,"i_data":"gQX15Vlna1iA3wm5KYT7M3L4ZjDfGj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1352,"i_im_id":3107,"i_name":"rf6V0JeVzw30yvdD9A3Dncp","i_price":86.67,"i_data":"GMXRgaDDfIRa05LdLHYUQMVzUgWMsA0OiY9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1353,"i_im_id":8419,"i_name":"3gZgg2iLfUmYTBR","i_price":39.97,"i_data":"G01XCThvCJIBu369e1EvKFmKXCVN2z98EJ2hqbBpdhCDB8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1354,"i_im_id":9697,"i_name":"qQebASxdzPNIE1J9Voe","i_price":66.49,"i_data":"MDZDcvncxLBve5Ey82Tnwiab4qexSV4QINdeNmlTnkp1P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1355,"i_im_id":5692,"i_name":"NezkXiKM7UGbahAr","i_price":46.09,"i_data":"YpsukEkQxlEmowh0lHkiR0bVn3bVNnnUS7qqgydz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1356,"i_im_id":7563,"i_name":"CCV6dlwGGoHIdKf","i_price":9.23,"i_data":"bdVUfbRP7h6sCF6aIvz2vq5mKeX8GFkxb0zNVb3WsyPe3qGIi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1357,"i_im_id":5306,"i_name":"z4LNvVvPttwYhL","i_price":81.03,"i_data":"caSgLILKylXMRIbIHDjcAAb3Vaw2qgk57WA9APInVXKUvj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1358,"i_im_id":9377,"i_name":"GM5o8awaZXgwZyUjkhk","i_price":54.65,"i_data":"SBqMKXyv94wC3byOyN5OCbexuwMbzDN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1359,"i_im_id":8496,"i_name":"vxnh14t05Ho74Qm0dbs","i_price":61.67,"i_data":"2KyQN9iN7ouylpvj0jZcITYYTH9lKcvXaVdWy8F4rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1360,"i_im_id":8211,"i_name":"MeE4R905c3IEc5","i_price":47.12,"i_data":"UrKQKiDA4aeAVFvdwVWpwraJAGxilFnzI9FGkdQbj5uDehF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1361,"i_im_id":3906,"i_name":"hPZJLAz1KlsLZok9","i_price":46.24,"i_data":"DQsejfD5CZgKOgIkW2jYjPNdyRFLjalC9W7NN83FeOPMZHl8b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1362,"i_im_id":60,"i_name":"xavgftQfXQ2FZL1PQtpo","i_price":5.93,"i_data":"DRXjXkAD3lsboriginalriuK8UO4HWaCU9DgjBRb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1363,"i_im_id":2425,"i_name":"3tU6P6Uw1hkfWnK1yMedSNq","i_price":90.49,"i_data":"sYSN1EtNarmvYtyaPOOGJ1WvRC9DMTtdFX3p8UI20hr6ZwWXV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1364,"i_im_id":9589,"i_name":"BCnDSGmdP1bUZcv1Yst4","i_price":80.25,"i_data":"jMMD2tpsZldMz4Wkq1TtRBdKezjazmIdsX16cGePoAb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1365,"i_im_id":2103,"i_name":"l2QD3Yi4varknBZ90d4P","i_price":8.99,"i_data":"wHGJiXYbKhdhLb6zqdQ3CJ3ihxR1TK4YZcBVts3wctLy1aoM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1366,"i_im_id":8420,"i_name":"RjyvNSmXxrxFCWcdPHIOp1i","i_price":61.16,"i_data":"TZwVxDxjUumBc42bkM5GLjAnJZ6HlXub9GUQsFhGHA6V68E0R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1367,"i_im_id":1635,"i_name":"RPagzGYCuPXB1DiZn7","i_price":75.83,"i_data":"EvT1DrN3qD6MM3b8gpm3QROqbTf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1368,"i_im_id":9414,"i_name":"h6LRC7dwMCl2CJQaTBNlEOKJ","i_price":93.35,"i_data":"Qoriginal29Syd64ibeC2HgnOXFTSwTjhP9uejkmo1oWOEn51"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1369,"i_im_id":4439,"i_name":"4Qz9D4O5tAeVFmMB0GL2Y","i_price":60.12,"i_data":"BOfprt4frT79QO7hZWJTOtF5BwQI9Irij"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1370,"i_im_id":936,"i_name":"beA2y6z30s7oejMo","i_price":50.15,"i_data":"pVy7q47fMD5JwJUS4XymwkK9YlkbitlQGDIH2XWj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1371,"i_im_id":2728,"i_name":"3V1uT4HmP7dGjefiFHL6g","i_price":28.43,"i_data":"y2ugXQzl8GnY0EMuEEf8pe1nzgU284g7JtVBxl5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1372,"i_im_id":2127,"i_name":"vtNClByfxwM1jcWmrZ","i_price":89.11,"i_data":"i2KfdZqw10R6gt7xDJERWCLrlEGCdCmlRNAVaIdxcT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1373,"i_im_id":1314,"i_name":"fhYd8bR1CrmDrpenFY3","i_price":32.38,"i_data":"MehyYYJ12UcJE0OaawE3FAn4T3hFzpTQo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1374,"i_im_id":6266,"i_name":"xpERJlyvsUZItE04J1Ifl","i_price":61.67,"i_data":"zSFdrTLN1fUsSLq61U7gpcERmOGmCVW3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1375,"i_im_id":2913,"i_name":"OkdHqmZSxXiqxCzmBbO","i_price":67.64,"i_data":"SG18gjJ2K1wbadtMMJrYaOJPP9wvYygzlkVSJE2DiBRudO43"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1376,"i_im_id":9022,"i_name":"jzinJ4R0vsFHfrayOjTLdk","i_price":97.96,"i_data":"Bt3xjFUhadPgPKMsGslqJben7Dy6xAqUo5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1377,"i_im_id":44,"i_name":"wqSXAkIu6hm6wOB9MypS","i_price":53.39,"i_data":"mvzT4AL2sVNc5xgRnBg5SiOKuvMIQSK9YBvHPml3YqmNHms"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1378,"i_im_id":1338,"i_name":"nrtf4ebujgXutVUQ24vvRX6A","i_price":90.85,"i_data":"274EPaHmNfHqIH8lRualrRWRoriginalptcs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1379,"i_im_id":5532,"i_name":"3Eq5jXIcCsxR3Rc","i_price":57.87,"i_data":"c4XRnuvhr5a7uhG5xthHOIxNBzxYpt3ES7aqhUY97PPCMJjR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739206,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1380,"i_im_id":6830,"i_name":"nzsDP3gGhpvHviTBiYm2Yeqd","i_price":46.77,"i_data":"CLPHdOepvI1qeHTH9kfHaQwh2ls4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739206,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1381,"i_im_id":6674,"i_name":"ZUxpDw11omdd7J78WVm","i_price":62.06,"i_data":"OmhzLzuKRJh7AR5oUn9UVOpUlWcfEBzGYqk0NOmxb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1382,"i_im_id":7350,"i_name":"IwvAdQtUeP5uGc","i_price":69.86,"i_data":"6qJeqsaRrC9ZhXRGGkDwavyg0DtI8mJRsV45BZz2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1383,"i_im_id":9463,"i_name":"uYnJACueQS9AHYVaclwcC89s","i_price":99.67,"i_data":"pPBLh418lxKUGUWtijXjInzNlAXe0mGcHV6vvH7MjpaNCb2cu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1384,"i_im_id":5194,"i_name":"VVM8O0ruc6ITW45Sl","i_price":70.55,"i_data":"tLWhUl5SXrEdg9u70skveaNsHdkptQZeaNzOnBb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1385,"i_im_id":2868,"i_name":"PUAA04ZRu2YSpYSl3Wp7JxfB","i_price":38.54,"i_data":"37E9lwvoriginalYeeRzbhgwnysmZNEbaKqK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1386,"i_im_id":4199,"i_name":"WLfo94mpw1o8Kbf2a","i_price":92.23,"i_data":"a6zAkxyGSGapPlclxjSRpcJIrF9lCzzF1ooQqMoek"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1387,"i_im_id":4763,"i_name":"m5tuJK7D4QfkTwNM4vvWkJTz","i_price":49.82,"i_data":"originalI1AG2gQywlUreCKKJNuViZejo7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1388,"i_im_id":7694,"i_name":"7cKdnL3mg1NFEIwNZ3cm","i_price":15.77,"i_data":"DixA9MCZiDtWkUFxWbGYAK2wXhp7vt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1389,"i_im_id":6427,"i_name":"P9jWWng639kr6huLW","i_price":85.11,"i_data":"Guqs5LTODHEJc2DJnk6qhofzIvOWOBUbqEAW9gd2s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1390,"i_im_id":9867,"i_name":"uvTCdgplgiN7Y1JysetLMFOd","i_price":49.47,"i_data":"RRdX3JkumRIUwd2Kb0EYlqIawAsOJVn0wSoMOF9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1391,"i_im_id":118,"i_name":"rDNSGptsMtRWWC7Ezy7","i_price":88.06,"i_data":"3fzKn45lphnVke36laAz3zixHn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1392,"i_im_id":8241,"i_name":"r0ToJLZC6ggPDyQZnGP","i_price":39.35,"i_data":"0Mjvn6XbNrRQKSZ7OWtDl9kGbwQAQVg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1393,"i_im_id":1443,"i_name":"yCQo33cLmsgVVxx","i_price":25.59,"i_data":"m6t61gMOj1UGPS9gDnRgVtOUYz2mDuyFvSRD8xNArzLOI5xpgw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1394,"i_im_id":7962,"i_name":"gPmMspDGLd4G497wOW4ZWLf","i_price":83.18,"i_data":"j5K9JzPTjPuN5fHBC1vDYSukV0uRUB8oPDcUfh5v5GjytYgmb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1395,"i_im_id":683,"i_name":"DGgSsFrTFpoi5C9DByr0WR","i_price":99.99,"i_data":"XYoG3xBLmHZc03qTtd2lu9RVrkY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1396,"i_im_id":8384,"i_name":"ASXqv2YwLuIrLDi","i_price":13.66,"i_data":"JZYworiginalIFFxciR6OiRsaJZYu0pEtlh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1397,"i_im_id":2823,"i_name":"7Z1DN0ASYM3S40VXQ8dHSjJh","i_price":7.22,"i_data":"BwdXnr5qqhUHxl5duiTlCTeB6J2795XmY1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1398,"i_im_id":5005,"i_name":"2oP4TTilONMlepaeUTX2H","i_price":59.54,"i_data":"0JAANwgrUzwh4Fev4ovIu6ELxPuhPodRJwVcB8Fg5HaGkl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1399,"i_im_id":5577,"i_name":"IYgLFtQBVB4NrgbbZs7","i_price":30.03,"i_data":"LyHQxk8Opkg652IywwuSKrkn5bm6bAJYImrXezDRCzg3mBgv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1400,"i_im_id":8047,"i_name":"MgJfIWjYMJq0VAnVvQ","i_price":52.86,"i_data":"O2jsD7tBHJcPoGiSdx4vSiU2n5MKbsnK7up3C6qPWAxWae2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1401,"i_im_id":2987,"i_name":"ihHMDJNMnz09bZXfk1esV","i_price":15.8,"i_data":"nvnUdC5xApDyJx9UoriginalZfNteYbDbk0hOCPvuf03"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1402,"i_im_id":3794,"i_name":"YRYovyciDIWo2WKzr","i_price":27.39,"i_data":"RgEf1dxwENIbPVDK6NCmnbpfoMXjZxmEJ3u0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1403,"i_im_id":8144,"i_name":"hSxKK0vhNaSjPVX7Ce3KjhMP","i_price":87.44,"i_data":"XGA2qxXfEoVgDUXCmx7ts9QsiZMtPDvu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1404,"i_im_id":9190,"i_name":"EQhjeKCZKj9FbTLAZv1B96","i_price":22.08,"i_data":"G1zQdFIYfGsF7GdkZUibUTWEuxOkCtdmzpvHhxCpUiLBvK7g2K"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1405,"i_im_id":6155,"i_name":"QP9NsYKE2oB04yrnpiM0","i_price":39.66,"i_data":"2xWkWVsmCShZsKucDYO3vndANRbLmVLiFX7hq34N5hG8q1sPT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1406,"i_im_id":2144,"i_name":"jbwjDKSPi1aSfODKn2","i_price":98.09,"i_data":"frYhD4NSS9tyyEIcAWrBQCNDBmSPCgj75tjEIhYAlv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1407,"i_im_id":569,"i_name":"0yutzesK1nDc0QJRAeof","i_price":31.47,"i_data":"R3JMk5SQ4ZGE7yVEFpuIFpeWQQrBJ53vTSU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1408,"i_im_id":5093,"i_name":"Ukm94cZvYUAOjDj7","i_price":24.29,"i_data":"gqDtn4KxKqYplDZ6aPbMsXQRnmlCUm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1409,"i_im_id":2713,"i_name":"hAdhqUNLC7oqNbtwNz","i_price":15.37,"i_data":"2CxSRAaICzpuMLfc1kAC24B2rVvdfD4OzbQi0jWf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1410,"i_im_id":4356,"i_name":"XSCZ2etE3GPKilgp","i_price":20.62,"i_data":"TWdW0Cq4S9S4fvXdJx5Ryb23EFQN64JnK1h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1411,"i_im_id":4363,"i_name":"kmguCIqw5Uwj5O9","i_price":93.76,"i_data":"3xNkgXPdcVJrxWFJOpo3GGAUr1GT6lYXcmJz1jzQrxW9HG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1412,"i_im_id":333,"i_name":"nry7fD2PxCq0cKcancYLQT","i_price":15.81,"i_data":"C8RLbd2wYjXhM27dLjdoGY044pKryf33TempO7G0z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1413,"i_im_id":9312,"i_name":"tBfoqUZc3nKcKLdDnA8","i_price":31.12,"i_data":"GDses92qB4EHOot8dQstuLHV1yyeCJiA7rNX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1414,"i_im_id":4138,"i_name":"15K6z7GHDqQh1Z8JUND7JS5","i_price":91.4,"i_data":"dgHZrcs5TnKIJcXV351pmRAiUxvlp2POHiv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1415,"i_im_id":215,"i_name":"X0ci0dQ6Clz1dOBXO6hYN","i_price":72.11,"i_data":"SH0gb5zX4kCXQ3DSbQQj3JtNo9yENIjVvvTYhRgpUJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1416,"i_im_id":659,"i_name":"ZF2AyMtnkYRKQHm7PZxlv","i_price":91.31,"i_data":"BxPLZfkeYr73eoHdFq9sd1ftrG715ijRSVONZQ4OtFdS96"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1417,"i_im_id":9014,"i_name":"hc6cCZUTgz3YSWkZ3DS","i_price":63.33,"i_data":"LqyL8L2AcAK5leAuDFBZUuu1A8AKwf0JTznI8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1418,"i_im_id":9865,"i_name":"UlEwPfof1obB6RpjtJ","i_price":69.57,"i_data":"oRUGvxA2GtM9LGgM8BiOLforiginalR0hkED5BjWv3cOz3G"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1419,"i_im_id":6820,"i_name":"OHsMTuqtHz6We4qEH","i_price":23.12,"i_data":"5NDBSQGyOmI8xA2oKyMsWe0cD7fFnSou2Go0hIeDcZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1420,"i_im_id":6257,"i_name":"h9hdpGErcPLbLbEY8RfNxk","i_price":19.26,"i_data":"x7Ki5HzC5eLLJV1Xao08Cs68xjCjts74RpJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1421,"i_im_id":6387,"i_name":"6v2mHTEGGqR8sqAP1qUWlz","i_price":87.87,"i_data":"Zn8rLGCLZu4xwuJ3xWdwNpfc2QYjOm8X5VxTwfFxvlbJ5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1422,"i_im_id":4998,"i_name":"kPmFgyW2JpBkyuPDEV","i_price":45.0,"i_data":"XYxcKwKPpOKu25y9WpzbB6sY9KUAY3X4wEhVZJb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1423,"i_im_id":4106,"i_name":"zDWUNTGRNSVHDtC34oEZ4E","i_price":86.19,"i_data":"3duQiGVQKShvRp5YqfLaWXOgR73Jtz2Y7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1424,"i_im_id":6197,"i_name":"iG1QCd7wzYOuwJ0jM","i_price":75.87,"i_data":"ZYdxo0MDkS9m3xEqkDJNnRYjiEH1bWlLUuXwGIWMy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1425,"i_im_id":5131,"i_name":"hJ8mOg8mPy2I9v0HmzZC9","i_price":2.48,"i_data":"S0zxY2TaISYqkfAgt22D0bqE0ZXYCJQxTjgg7X64b0GJOVUS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1426,"i_im_id":8190,"i_name":"dyaFdJOlQj8RmqwU3kR9wd","i_price":8.62,"i_data":"9wb7DQYHTU72xcnTVj75ij8dthioevWz66QH8lrdKbk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1427,"i_im_id":8834,"i_name":"3ABzYWHvv9FjVi","i_price":68.04,"i_data":"pzDxKnnhetLrK8OBpvDIRQONmpVVrLqM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1428,"i_im_id":4433,"i_name":"6bHlYLAG8QHj4XvCDXLrIwXc","i_price":15.09,"i_data":"2uAWtSHdWiXQJ5VMx9LI9AXxr9originaldVwRK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1429,"i_im_id":7940,"i_name":"3rl6Rp9M1cu3vIbKy3VZPAR","i_price":87.74,"i_data":"AwTtGhutrKf2DTYyssn08lG24oVyqeWZRMQGchFmqMm0Uym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1430,"i_im_id":679,"i_name":"fbEhfFT2WHwwhfUoxHH","i_price":38.48,"i_data":"DwrtbJUFZ1eUgrN0xt3AMa7lIp3lLB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1431,"i_im_id":2373,"i_name":"K631vkfNc2MCl5v","i_price":60.47,"i_data":"PiEWFelMoYUahzHVAHRuBeFFEcalj3fq1LjKC86Cb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1432,"i_im_id":5164,"i_name":"s43AZxvAuX5cryV","i_price":7.71,"i_data":"NeLmp2B7JCoFJirNGdxeBlsqKhoGJbmBmD88pYunb2o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1433,"i_im_id":9295,"i_name":"9om9GszdJdFiVt5","i_price":82.33,"i_data":"wSBsD1Hxd93U0ha03UrD8DW0ECcBbdY12"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1434,"i_im_id":6827,"i_name":"ZRd0N7ngdjsghO8qP","i_price":24.98,"i_data":"7UJIB1nPZC8Gj45IqD18JkPB0HkGSR4CfnBDjxU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1435,"i_im_id":9466,"i_name":"tJR3s3j9B7uEIRqrzfEVYe2","i_price":21.3,"i_data":"u7gvKRrfs2isKJ0IN8pqChaMDGwQHecL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1436,"i_im_id":3677,"i_name":"5WXZVf8liaJScjU2Rvha","i_price":9.26,"i_data":"sUxvqOh90fha7iTk0bSAuBhiruayCxFzBCRvN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1437,"i_im_id":7039,"i_name":"X7JROHrCbnFu4nz9L","i_price":88.53,"i_data":"jrTwo5JvuzzcGc2wSZEASZZv4i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1438,"i_im_id":1516,"i_name":"X2HeRVwr3HwW5UgUoPq","i_price":68.33,"i_data":"cNSYkPnSgsuoQgvl33VtHh28R2Zsnzzpflnv9RfboNpzS7oL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1439,"i_im_id":4071,"i_name":"F7cGzjaNlHu1zwpVtB","i_price":42.18,"i_data":"OpEJPnTqXwBkEPJaeybyEhMInMDcrmnL7jsUt1qToCv9H"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1440,"i_im_id":908,"i_name":"a7LCN189wUUjodznR3cGxSg","i_price":74.79,"i_data":"1FuE16gB1CgCs0HXFUuHWNVinrBC8qJ1Cgiu5IEQaYCgjbSUM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1441,"i_im_id":1264,"i_name":"WEDI4uzoPrq4IeIkbjG8","i_price":75.18,"i_data":"l2bimx9KkE4dMybRutmhEIUuBK5B02yK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1442,"i_im_id":9170,"i_name":"TF7LQG2WKvjP7WkAFU","i_price":54.2,"i_data":"A1OBEDPteunuuFZNWfIPjriKlrcJbmgXLedn4lQqcNadMpb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1443,"i_im_id":2568,"i_name":"tf54wabdRnf3NHdYVxzOg","i_price":95.26,"i_data":"3VcBGpqm4NTX5ISaZ4IqFwOCHmQqNxfaXH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1444,"i_im_id":5652,"i_name":"6WFuGuN5nT5MSeSPVptx","i_price":63.22,"i_data":"yUhp3wo164vPxbtbYllTDDfRo0H2Ubgwn9fDDVLCkfgEJP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1445,"i_im_id":505,"i_name":"S2VqQgWqhS3RoVlviTr96R","i_price":32.75,"i_data":"htKV395ArWqT5dEiTJLqT7pDH0zEPG9jyfmfrL00r0HrTNXB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1446,"i_im_id":6039,"i_name":"csiDTpZeRu6KzdVEUkO7","i_price":41.4,"i_data":"csT1yRYxGQBh1z2O1kwWpNG0hcH99IfmZb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1447,"i_im_id":7150,"i_name":"PhzrsGUN9PoBD3mSwcl6y","i_price":47.26,"i_data":"ciKc6aFQ28TsUVFV9l2eWNFfLgBdXTW5cSWR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1448,"i_im_id":6555,"i_name":"Au2WFtP6KvuHiJJqXMHL","i_price":55.44,"i_data":"BdJbxSOpH4aQwXGJ6Z2ykaOKgFmPGeUv3xPk5aHdmlLj9qn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1449,"i_im_id":7502,"i_name":"JFYBegwYX1am8w43jzKO","i_price":85.85,"i_data":"W5whDfJ9mcmMsoHjvfAoeyMuyYEhU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1450,"i_im_id":3388,"i_name":"Ex7bDUL8AqWUXTjIzYGA","i_price":7.97,"i_data":"cWwfxv5lIEKTE9XrUdyuz6jhjsJEJGokv6K"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1451,"i_im_id":8459,"i_name":"xWLVk81UzxCLYHDTkL","i_price":90.35,"i_data":"2vdHPSoJXyU9AJrKt8znGGwvHq5ZV4Jf3bjLYYAOsJy8TWy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1452,"i_im_id":1246,"i_name":"9HQKEdIKzGUQsJSCsaHWwh","i_price":70.6,"i_data":"Jyw2ZigCAr83uvHwbvwpjsXJBT8BSPXvnMJrMjaYMWs3p"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1453,"i_im_id":4695,"i_name":"hMtBlFE2zJyiq2C750AJv7ka","i_price":52.75,"i_data":"by35nMuCBtWrhjl6kUsL08xhwp9qWtaBlztZaDpCofq5h8CB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1454,"i_im_id":2262,"i_name":"zTjEQkKztB9qh57r","i_price":45.86,"i_data":"MpRQxcuBNTS4mHA0g5IPfeFpJHtL3dYKwX4wG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1455,"i_im_id":3038,"i_name":"5ZHGysQtIiH9JimlltPWziA9","i_price":45.59,"i_data":"sUia1wVxOyQwGWjiuOG7DciZpPb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1456,"i_im_id":9589,"i_name":"vROPqIOdNcQXlGu","i_price":41.75,"i_data":"vw64a4tHbNvncLplUI6SmxenUV7JUtM5m5cD6fp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1457,"i_im_id":7549,"i_name":"XdBIsMbPUePSW3Mm6KcYIuR","i_price":81.88,"i_data":"ryWA3znfHNg2EIDAD51RsxLLZDQydL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1458,"i_im_id":6639,"i_name":"0J136pDbmZCEMPUwEk","i_price":13.33,"i_data":"dVOxOurVK0QVOHnI3G6UvbsbmDpZIb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1459,"i_im_id":5800,"i_name":"II9jdUUIdqWJzulv8jVrGC","i_price":28.72,"i_data":"69AD6YANec6yE8tpzkg4AUYi9Egs0YzddGDSuij2mTwAukW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1460,"i_im_id":8064,"i_name":"n6JMwoZhy8DIv5","i_price":5.42,"i_data":"ADOxITaWlspXAYTMekdchuQZcqmmOsZSUI5PFNT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1461,"i_im_id":3649,"i_name":"SYpRauEMoP4FebQKefDOqV","i_price":12.48,"i_data":"aZ7EoEs9gaVxasLOYxos120K5dH81xzuccn0koUUO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1462,"i_im_id":405,"i_name":"6H3pGnNeCVsHlaqvePHdnB","i_price":61.2,"i_data":"cDbgRHIlqMEMmkS66g8CwCJ60jg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1463,"i_im_id":6458,"i_name":"JPyhk3kyBhZGUskKjgteW4gy","i_price":6.11,"i_data":"HqlBgp8PpXr8zdpSEmA3Gf0RDwwQ443reiuuZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1464,"i_im_id":4659,"i_name":"ugHT9UFOYGKLTF42Xo9T","i_price":96.12,"i_data":"CVhxWqh04dmxSSzcJI9dI7XWCXCfZkbnPn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1465,"i_im_id":9424,"i_name":"qgyo23KYSduq4rSGhmZdy","i_price":63.24,"i_data":"dCE3wPoI26a9f8gwAje2whSB5pRZQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1466,"i_im_id":5119,"i_name":"qf36p9CoGxOXIQ","i_price":66.28,"i_data":"1ltdefxiHNUVjTl04t41Ey7ulTRA1qCoozRbj1fCQ0TWlmEVV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1467,"i_im_id":9235,"i_name":"nTNXT9GgQqd4SpUDlakQt","i_price":72.96,"i_data":"YkLDvcZSphZ2diEo6SWPFEqqbMF1V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1468,"i_im_id":5277,"i_name":"SgRgaqpdUruKTGIBm","i_price":64.87,"i_data":"oukjtsGmBWS8ju1Ufd8zo4eQpcZBXs0v0JFiQWDufiK2Ab"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1469,"i_im_id":675,"i_name":"CR444XAMHXYXTTwLfQR","i_price":98.68,"i_data":"fMZxEzcbx7oYUF8wn8oVOtAG0QhCRCo4lDPAtbMO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1470,"i_im_id":3019,"i_name":"OndJRMmuEHmumgwSQ","i_price":81.96,"i_data":"WvvK8HIIRWxlbR5Hu9F9sSZ4PrA2quPDc4b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1471,"i_im_id":3209,"i_name":"2qCbVcpHLzUPfAewtNVc0dD5","i_price":72.59,"i_data":"Ifc09pF7SkcDfdHiPoriginaljGzE53jK2NBDaHer2r88Z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1472,"i_im_id":4571,"i_name":"w1WlXjmk4NIYWGxJbPJJK24","i_price":69.54,"i_data":"Rvsw6Eq969dPCY82lXZUDjLL4TL7nveQ6I32RqP7GO2eThN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1473,"i_im_id":4536,"i_name":"z4Kt5fRtrD2I4Jun0idlD7s","i_price":80.61,"i_data":"Od7DPefVsvo1UGpm3J5uMtoTY9O4kL6vb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1474,"i_im_id":2378,"i_name":"JLSwl5qvOtFe8Tg","i_price":70.5,"i_data":"gu6yApWvErEQTMSY2WZtDwB57PKeH2tYUaPSC8FNCvwWyo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1475,"i_im_id":2851,"i_name":"8c6XsicYBPr7fpd9r6pf2pe","i_price":86.43,"i_data":"XSOWvRCPhzvbMeMTAwKQ47YreA5JdtvNWvU0Ub"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1476,"i_im_id":3467,"i_name":"RPieMYuSQPs5BuR51YJPRlF","i_price":2.08,"i_data":"kO4hNfac3knzkUloj8gFvB8gP6Ub"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1477,"i_im_id":6787,"i_name":"e08I7ldipVbAzdci","i_price":97.9,"i_data":"BNWIRIr2vnWgSPhFFGljCHTzIq2WYUn5v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1478,"i_im_id":4572,"i_name":"js2VRcxAqbUdcIo","i_price":74.43,"i_data":"MicEb9hsIeYVl60GrADCHtA0yphFn8sEqPROU1MIW7hlCb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1479,"i_im_id":8142,"i_name":"g4j6Af6X7hAQlC8kV","i_price":94.04,"i_data":"1Z2EWseSitNTKW7Ytd4UXdotY87iPu6So0DQt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1480,"i_im_id":6866,"i_name":"CL6yDYFT0iZqye","i_price":19.63,"i_data":"Rli0Z3tVNW04VBLx6WxhxALfItBezNKHGDVNx2QlATNYz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1481,"i_im_id":8402,"i_name":"yvpKM5VDTQ80aN7rZncvZM","i_price":78.57,"i_data":"c0X8bgwAf91bKWP7KFOewqPa6U0Gf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1482,"i_im_id":2073,"i_name":"wIaqUBG25Yzbu7ZxR","i_price":16.07,"i_data":"c0J8inCNPPjoQe3lDQAzf9M8OiOwns6iiS1lTYYJmT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1483,"i_im_id":487,"i_name":"Z48sH6I08VcP1oGRtzfq8CfJ","i_price":39.85,"i_data":"6P5vMVCa3gLv0JVJ5GfrKY3FlEmFsxrr7a6oT14OcHkju5upzj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1484,"i_im_id":954,"i_name":"KuhmGF6tKQP7Fr","i_price":81.54,"i_data":"u7OvJg6C9pOjX2f77xC1jvGFzlEeBOfDftGWh6jDX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1485,"i_im_id":7573,"i_name":"qqcD83Qn1wgQlLzYuD5","i_price":29.13,"i_data":"zzO5FsqxvyjfOlSWZ5AGVcEO3L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1486,"i_im_id":8378,"i_name":"kZipybmtluQgdWdrHnvIFR","i_price":59.43,"i_data":"tlAetrfS3POMI88originalVFKFIf6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1487,"i_im_id":3575,"i_name":"bI7NQK0ayJdC3yVs","i_price":25.36,"i_data":"naYssRPC4vfyfTGl16mIHclAYsTwE9hBn2GPLZJ8NUhP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1488,"i_im_id":4992,"i_name":"89PLWOTGJBZ8dm","i_price":23.5,"i_data":"xdaCDjlJwqbTC1A5fE9fWchzZQvKTDAIyg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1489,"i_im_id":3428,"i_name":"DN88TyvqAlo0gNJ","i_price":66.65,"i_data":"FtN5mpi9uTTMHfwmFzEx2XzMHKYQAb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1490,"i_im_id":9747,"i_name":"cnch8V5fWDlpXH5gbQ","i_price":96.72,"i_data":"zijAaS3YWSLnmM58IxEcgo0xdStJ5KEwxU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1491,"i_im_id":5675,"i_name":"5K0SqxD8WVEvXII","i_price":5.7,"i_data":"KRTj2TjGByYRHorruJ9ieA4K5QiDsTrmVxeMT4tl1kNkIX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1492,"i_im_id":4033,"i_name":"gPHLtWz0iYkJnTSGDVBR4","i_price":62.07,"i_data":"jgSb9XvM3gwPCvTYqPfvBwO1Af09sw3GpUdrIr1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1493,"i_im_id":2671,"i_name":"2eKq9Za122IRHLkrnh5I42X","i_price":13.4,"i_data":"f1ZTeYX65F4aMbPluiuB7Sg5yP4RC2B5VstQTHdmNBMs6kss"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1494,"i_im_id":5465,"i_name":"8WGccvW3OYjz96jE","i_price":88.34,"i_data":"deEmKkNP5KdGn1jO0b9ZG6plB0O1a3cY5nFE0yIQO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1495,"i_im_id":6539,"i_name":"0CE4MnYQ9nyebKYTXZ6la","i_price":58.31,"i_data":"ZpkxdEY3pAKJvHFKN2EW0XdywcEVdJ47VR7gQsXXEosyx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1496,"i_im_id":345,"i_name":"tHnsNjID2XM0QaCrveL2hHxW","i_price":65.35,"i_data":"tgLoriginal1OrLhXEQkt6rQCrM68w9Rb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1497,"i_im_id":1861,"i_name":"0nFShQXFGwt2VQd5","i_price":85.79,"i_data":"nWMHhGybQctdVer9QCpe3KQtC5fzo8V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1498,"i_im_id":9602,"i_name":"mVDyAXKJMJzhxVVIBVLE","i_price":45.47,"i_data":"WQt9zcVgOLmHhldKP11phb28pBlrJM18DmhlgBYWn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1499,"i_im_id":3588,"i_name":"WIH3SOeP0yXH5nEK0qXoLH","i_price":86.04,"i_data":"EokEZRheZp4rUJ7dp5h3m4nhdblxdrr0WWPx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1500,"i_im_id":6996,"i_name":"946rW7iiQldO7gjU","i_price":46.97,"i_data":"6dusWPGvNZglox5xpenpPg0S6qYhdoWTDFt6Iw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"item","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739207,"transaction":null}} diff --git a/scripts/source/test_data/tpcc_neworder.1 b/scripts/source/test_data/neworder.1 similarity index 73% rename from scripts/source/test_data/tpcc_neworder.1 rename to scripts/source/test_data/neworder.1 index 3b0029f426c29..5fe1d4b8d2aa1 100644 --- a/scripts/source/test_data/tpcc_neworder.1 +++ b/scripts/source/test_data/neworder.1 @@ -1,107 +1,140 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081186,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081186,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081186,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081186,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081186,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081186,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081186,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081186,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081187,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081187,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081187,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081187,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081187,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081187,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081188,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081188,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081189,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081189,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081190,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081190,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081191,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"neworder","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081191,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2105,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24406400\"]","schema":"public","table":"neworder","txId":1325,"lsn":24406400,"xmin":null},"op":"d","ts_ms":1664141081520,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2106,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24414032\"]","schema":"public","table":"neworder","txId":1326,"lsn":24414032,"xmin":null},"op":"d","ts_ms":1664141081521,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2107,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24433888\"]","schema":"public","table":"neworder","txId":1327,"lsn":24433888,"xmin":null},"op":"d","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2108,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24453976\"]","schema":"public","table":"neworder","txId":1328,"lsn":24453976,"xmin":null},"op":"d","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2109,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24464968\"]","schema":"public","table":"neworder","txId":1329,"lsn":24464968,"xmin":null},"op":"d","ts_ms":1664141081525,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3011,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24465088\"]","schema":"public","table":"neworder","txId":1330,"lsn":24465088,"xmin":null},"op":"c","ts_ms":1664141081525,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3012,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24492632\"]","schema":"public","table":"neworder","txId":1331,"lsn":24492632,"xmin":null},"op":"c","ts_ms":1664141081534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2105,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2106,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2107,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2108,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2109,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2110,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739212,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739212,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2111,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2112,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2113,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":1,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":2,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":3,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":4,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":5,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":6,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":7,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":8,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":9,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":2114,"no_d_id":10,"no_w_id":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739213,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"neworder","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739213,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2105,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25539480\"]","schema":"public","table":"neworder","txId":4499,"lsn":25539480,"xmin":null},"op":"d","ts_ms":1665511743076,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2106,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25546912\"]","schema":"public","table":"neworder","txId":4500,"lsn":25546912,"xmin":null},"op":"d","ts_ms":1665511743080,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2107,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25566704\"]","schema":"public","table":"neworder","txId":4501,"lsn":25566704,"xmin":null},"op":"d","ts_ms":1665511743082,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2108,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25586728\"]","schema":"public","table":"neworder","txId":4502,"lsn":25586728,"xmin":null},"op":"d","ts_ms":1665511743083,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2109,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25610120\"]","schema":"public","table":"neworder","txId":4503,"lsn":25610120,"xmin":null},"op":"d","ts_ms":1665511743084,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2110,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25628720\"]","schema":"public","table":"neworder","txId":4504,"lsn":25628720,"xmin":null},"op":"d","ts_ms":1665511743085,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2111,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25640464\"]","schema":"public","table":"neworder","txId":4505,"lsn":25640464,"xmin":null},"op":"d","ts_ms":1665511743087,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2112,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25643576\"]","schema":"public","table":"neworder","txId":4506,"lsn":25643576,"xmin":null},"op":"d","ts_ms":1665511743088,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2113,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25655344\"]","schema":"public","table":"neworder","txId":4507,"lsn":25655344,"xmin":null},"op":"d","ts_ms":1665511743089,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":{"no_o_id":2114,"no_d_id":1,"no_w_id":1},"after":null,"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25667192\"]","schema":"public","table":"neworder","txId":4508,"lsn":25667192,"xmin":null},"op":"d","ts_ms":1665511743090,"transaction":null}} + +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3011,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25668640\"]","schema":"public","table":"neworder","txId":4509,"lsn":25668640,"xmin":null},"op":"c","ts_ms":1665511743108,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3012,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25698104\"]","schema":"public","table":"neworder","txId":4510,"lsn":25698104,"xmin":null},"op":"c","ts_ms":1665511743133,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3013,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25703384\"]","schema":"public","table":"neworder","txId":4511,"lsn":25703384,"xmin":null},"op":"c","ts_ms":1665511743157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3014,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25708600\"]","schema":"public","table":"neworder","txId":4512,"lsn":25708600,"xmin":null},"op":"c","ts_ms":1665511743178,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3015,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25713880\"]","schema":"public","table":"neworder","txId":4513,"lsn":25713880,"xmin":null},"op":"c","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3016,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25719096\"]","schema":"public","table":"neworder","txId":4514,"lsn":25719096,"xmin":null},"op":"c","ts_ms":1665511743226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3017,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25724408\"]","schema":"public","table":"neworder","txId":4515,"lsn":25724408,"xmin":null},"op":"c","ts_ms":1665511743250,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3018,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25729600\"]","schema":"public","table":"neworder","txId":4516,"lsn":25729600,"xmin":null},"op":"c","ts_ms":1665511743330,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3019,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25734912\"]","schema":"public","table":"neworder","txId":4517,"lsn":25734912,"xmin":null},"op":"c","ts_ms":1665511743357,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3020,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25740128\"]","schema":"public","table":"neworder","txId":4518,"lsn":25740128,"xmin":null},"op":"c","ts_ms":1665511743381,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3021,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25745416\"]","schema":"public","table":"neworder","txId":4519,"lsn":25745416,"xmin":null},"op":"c","ts_ms":1665511743403,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3022,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25759320\"]","schema":"public","table":"neworder","txId":4520,"lsn":25759320,"xmin":null},"op":"c","ts_ms":1665511743427,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3023,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25764664\"]","schema":"public","table":"neworder","txId":4521,"lsn":25764664,"xmin":null},"op":"c","ts_ms":1665511743449,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3024,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25769912\"]","schema":"public","table":"neworder","txId":4522,"lsn":25769912,"xmin":null},"op":"c","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3025,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25775192\"]","schema":"public","table":"neworder","txId":4523,"lsn":25775192,"xmin":null},"op":"c","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3026,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25780472\"]","schema":"public","table":"neworder","txId":4524,"lsn":25780472,"xmin":null},"op":"c","ts_ms":1665511743515,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3027,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25785728\"]","schema":"public","table":"neworder","txId":4525,"lsn":25785728,"xmin":null},"op":"c","ts_ms":1665511743534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3028,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25791008\"]","schema":"public","table":"neworder","txId":4526,"lsn":25791008,"xmin":null},"op":"c","ts_ms":1665511743552,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3029,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25796264\"]","schema":"public","table":"neworder","txId":4527,"lsn":25796264,"xmin":null},"op":"c","ts_ms":1665511743570,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"no_o_id"},{"type":"int32","optional":false,"field":"no_d_id"},{"type":"int32","optional":false,"field":"no_w_id"}],"optional":true,"name":"postgres.public.neworder.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.neworder.Envelope"},"payload":{"before":null,"after":{"no_o_id":3030,"no_d_id":1,"no_w_id":2},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25801544\"]","schema":"public","table":"neworder","txId":4528,"lsn":25801544,"xmin":null},"op":"c","ts_ms":1665511743593,"transaction":null}} diff --git a/scripts/source/test_data/orderline.1 b/scripts/source/test_data/orderline.1 new file mode 100644 index 0000000000000..8c6c61e0ae817 --- /dev/null +++ b/scripts/source/test_data/orderline.1 @@ -0,0 +1,750 @@ +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":4321.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739215,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":16489,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":42.0,"ol_dist_info":"RPN2 Rmigk66N0wi2LPiy Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":41270,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PRgyyLRNmRywRBNBNPNw6NP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":1730,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" NNNB64Ly i4iRw k6RkL2PB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":95420,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":" k6kw6P0wBL4ggL0B4LmBL42"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":8186,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mgg2yiRLim B0g2RLN iy0m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":21.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":60815,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2yiP4PN46m2w6g0gBN iwRk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":2117,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BNkg Pkm2Ry266R0RBRi i m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":2883,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mk6y24kmmwPwyL4Pi RLNg06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":25700,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.21,"ol_dist_info":"24RBg0N 2Ng 4ym0yyP RN64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":13643,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"miNN6g4imkgm kgBgRmP N w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":5140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wgwikiykN6wRmk0RmkLR4kRw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":62964,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"6 gP 62LPR Rm Ni2g442P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":4036,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gRw0kgk4g k6Pywki4Rk4L6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":55980,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w B004Lgk4N2NN40m00P0626"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":19100,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"k6i PkkPikR60gg6N2imByNN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":49466,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ymgy w6RLRwymiLPmiRgP0RP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":23810,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RB4yBiBimR wB4LPmLgPwmm2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":5189,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2gNLRk y2LR 6BP gyP060k4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":86260,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"6mmkLgR4L6iwL2 02Bi40i60"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":24557,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i0PmwgykgiyRk2mLig6Lwk2m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":6,"ol_amount":132.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":7,"ol_amount":543.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739216,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739216,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":8,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":9,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739217,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739217,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":8745.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739218,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739218,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":998.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":16489,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":42.0,"ol_dist_info":"RPN2 Rmigk66N0wi2LPiy Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":41270,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PRgyyLRNmRywRBNBNPNw6NP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":1730,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" NNNB64Ly i4iRw k6RkL2PB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":95420,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":" k6kw6P0wBL4ggL0B4LmBL42"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":8186,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mgg2yiRLim B0g2RLN iy0m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":21.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":60815,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2yiP4PN46m2w6g0gBN iwRk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":2117,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BNkg Pkm2Ry266R0RBRi i m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":2883,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mk6y24kmmwPwyL4Pi RLNg06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":25700,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.21,"ol_dist_info":"24RBg0N 2Ng 4ym0yyP RN64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":13643,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"miNN6g4imkgm kgBgRmP N w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":5140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wgwikiykN6wRmk0RmkLR4kRw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":62964,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"6 gP 62LPR Rm Ni2g442P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":4036,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gRw0kgk4g k6Pywki4Rk4L6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":55980,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w B004Lgk4N2NN40m00P0626"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":19100,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"k6i PkkPikR60gg6N2imByNN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":49466,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ymgy w6RLRwymiLPmiRgP0RP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":23810,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RB4yBiBimR wB4LPmLgPwmm2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":5189,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2gNLRk y2LR 6BP gyP060k4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":86260,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"6mmkLgR4L6iwL2 02Bi40i60"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":24557,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i0PmwgykgiyRk2mLig6Lwk2m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":10,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":10,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":10,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2111,"ol_d_id":10,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739219,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739219,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2112,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2113,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739220,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739220,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2114,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2115,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":11,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-23 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739221,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739221,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2116,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739222,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orderline","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739222,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.985762","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25514592\"]","schema":"public","table":"orderline","txId":4499,"lsn":25514592,"xmin":null},"op":"u","ts_ms":1665511743068,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.985762","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25522064\"]","schema":"public","table":"orderline","txId":4499,"lsn":25522064,"xmin":null},"op":"u","ts_ms":1665511743068,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.985762","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25522440\"]","schema":"public","table":"orderline","txId":4499,"lsn":25522440,"xmin":null},"op":"u","ts_ms":1665511743068,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.985762","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25522816\"]","schema":"public","table":"orderline","txId":4499,"lsn":25522816,"xmin":null},"op":"u","ts_ms":1665511743069,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.985762","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25523192\"]","schema":"public","table":"orderline","txId":4499,"lsn":25523192,"xmin":null},"op":"u","ts_ms":1665511743069,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.999078","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25544288\"]","schema":"public","table":"orderline","txId":4500,"lsn":25544288,"xmin":null},"op":"u","ts_ms":1665511743078,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.999078","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25544528\"]","schema":"public","table":"orderline","txId":4500,"lsn":25544528,"xmin":null},"op":"u","ts_ms":1665511743079,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":6,"ol_amount":132.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.999078","ol_quantity":6,"ol_amount":132.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25544768\"]","schema":"public","table":"orderline","txId":4500,"lsn":25544768,"xmin":null},"op":"u","ts_ms":1665511743079,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.999078","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25545008\"]","schema":"public","table":"orderline","txId":4500,"lsn":25545008,"xmin":null},"op":"u","ts_ms":1665511743079,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:02.999078","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25545248\"]","schema":"public","table":"orderline","txId":4500,"lsn":25545248,"xmin":null},"op":"u","ts_ms":1665511743079,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.009256","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25555408\"]","schema":"public","table":"orderline","txId":4501,"lsn":25555408,"xmin":null},"op":"u","ts_ms":1665511743080,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.009256","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25555784\"]","schema":"public","table":"orderline","txId":4501,"lsn":25555784,"xmin":null},"op":"u","ts_ms":1665511743081,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":7,"ol_amount":543.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.009256","ol_quantity":7,"ol_amount":543.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25556160\"]","schema":"public","table":"orderline","txId":4501,"lsn":25556160,"xmin":null},"op":"u","ts_ms":1665511743081,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.009256","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25556536\"]","schema":"public","table":"orderline","txId":4501,"lsn":25556536,"xmin":null},"op":"u","ts_ms":1665511743082,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.009256","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25556912\"]","schema":"public","table":"orderline","txId":4501,"lsn":25556912,"xmin":null},"op":"u","ts_ms":1665511743082,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.018574","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25575200\"]","schema":"public","table":"orderline","txId":4502,"lsn":25575200,"xmin":null},"op":"u","ts_ms":1665511743082,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.018574","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25575600\"]","schema":"public","table":"orderline","txId":4502,"lsn":25575600,"xmin":null},"op":"u","ts_ms":1665511743082,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":8,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.018574","ol_quantity":8,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25575976\"]","schema":"public","table":"orderline","txId":4502,"lsn":25575976,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.018574","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25576352\"]","schema":"public","table":"orderline","txId":4502,"lsn":25576352,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.018574","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25576728\"]","schema":"public","table":"orderline","txId":4502,"lsn":25576728,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.027358","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25599656\"]","schema":"public","table":"orderline","txId":4503,"lsn":25599656,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.027358","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25599896\"]","schema":"public","table":"orderline","txId":4503,"lsn":25599896,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":9,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.027358","ol_quantity":9,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25600160\"]","schema":"public","table":"orderline","txId":4503,"lsn":25600160,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.027358","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25600400\"]","schema":"public","table":"orderline","txId":4503,"lsn":25600400,"xmin":null},"op":"u","ts_ms":1665511743084,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.027358","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25600640\"]","schema":"public","table":"orderline","txId":4503,"lsn":25600640,"xmin":null},"op":"u","ts_ms":1665511743084,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.037253","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25618672\"]","schema":"public","table":"orderline","txId":4504,"lsn":25618672,"xmin":null},"op":"u","ts_ms":1665511743084,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.037253","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25626144\"]","schema":"public","table":"orderline","txId":4504,"lsn":25626144,"xmin":null},"op":"u","ts_ms":1665511743084,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":8745.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.037253","ol_quantity":5,"ol_amount":8745.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25626520\"]","schema":"public","table":"orderline","txId":4504,"lsn":25626520,"xmin":null},"op":"u","ts_ms":1665511743085,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.037253","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25626896\"]","schema":"public","table":"orderline","txId":4504,"lsn":25626896,"xmin":null},"op":"u","ts_ms":1665511743085,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.037253","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25627272\"]","schema":"public","table":"orderline","txId":4504,"lsn":25627272,"xmin":null},"op":"u","ts_ms":1665511743085,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.047012","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25637280\"]","schema":"public","table":"orderline","txId":4505,"lsn":25637280,"xmin":null},"op":"u","ts_ms":1665511743086,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.047012","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25637656\"]","schema":"public","table":"orderline","txId":4505,"lsn":25637656,"xmin":null},"op":"u","ts_ms":1665511743086,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.047012","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25638032\"]","schema":"public","table":"orderline","txId":4505,"lsn":25638032,"xmin":null},"op":"u","ts_ms":1665511743086,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.047012","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25638408\"]","schema":"public","table":"orderline","txId":4505,"lsn":25638408,"xmin":null},"op":"u","ts_ms":1665511743086,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"after":{"ol_o_id":2111,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.047012","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25638784\"]","schema":"public","table":"orderline","txId":4505,"lsn":25638784,"xmin":null},"op":"u","ts_ms":1665511743086,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.056118","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25640880\"]","schema":"public","table":"orderline","txId":4506,"lsn":25640880,"xmin":null},"op":"u","ts_ms":1665511743087,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.056118","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25641144\"]","schema":"public","table":"orderline","txId":4506,"lsn":25641144,"xmin":null},"op":"u","ts_ms":1665511743087,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.056118","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25641384\"]","schema":"public","table":"orderline","txId":4506,"lsn":25641384,"xmin":null},"op":"u","ts_ms":1665511743087,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.056118","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25641624\"]","schema":"public","table":"orderline","txId":4506,"lsn":25641624,"xmin":null},"op":"u","ts_ms":1665511743087,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2112,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.056118","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25641864\"]","schema":"public","table":"orderline","txId":4506,"lsn":25641864,"xmin":null},"op":"u","ts_ms":1665511743088,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.066071","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25652136\"]","schema":"public","table":"orderline","txId":4507,"lsn":25652136,"xmin":null},"op":"u","ts_ms":1665511743088,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.066071","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25652512\"]","schema":"public","table":"orderline","txId":4507,"lsn":25652512,"xmin":null},"op":"u","ts_ms":1665511743088,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.066071","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25652888\"]","schema":"public","table":"orderline","txId":4507,"lsn":25652888,"xmin":null},"op":"u","ts_ms":1665511743088,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.066071","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25653264\"]","schema":"public","table":"orderline","txId":4507,"lsn":25653264,"xmin":null},"op":"u","ts_ms":1665511743088,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2113,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.066071","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25653640\"]","schema":"public","table":"orderline","txId":4507,"lsn":25653640,"xmin":null},"op":"u","ts_ms":1665511743089,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.074653","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25663904\"]","schema":"public","table":"orderline","txId":4508,"lsn":25663904,"xmin":null},"op":"u","ts_ms":1665511743089,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.074653","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25664280\"]","schema":"public","table":"orderline","txId":4508,"lsn":25664280,"xmin":null},"op":"u","ts_ms":1665511743089,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":5,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.074653","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25664656\"]","schema":"public","table":"orderline","txId":4508,"lsn":25664656,"xmin":null},"op":"u","ts_ms":1665511743089,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.074653","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25665032\"]","schema":"public","table":"orderline","txId":4508,"lsn":25665032,"xmin":null},"op":"u","ts_ms":1665511743089,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2114,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-10-11 18:09:03.074653","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25665408\"]","schema":"public","table":"orderline","txId":4508,"lsn":25665408,"xmin":null},"op":"u","ts_ms":1665511743090,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25672064\"]","schema":"public","table":"orderline","txId":4509,"lsn":25672064,"xmin":null},"op":"c","ts_ms":1665511743116,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25693880\"]","schema":"public","table":"orderline","txId":4509,"lsn":25693880,"xmin":null},"op":"c","ts_ms":1665511743120,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25694920\"]","schema":"public","table":"orderline","txId":4509,"lsn":25694920,"xmin":null},"op":"c","ts_ms":1665511743120,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25695952\"]","schema":"public","table":"orderline","txId":4509,"lsn":25695952,"xmin":null},"op":"c","ts_ms":1665511743121,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25696968\"]","schema":"public","table":"orderline","txId":4509,"lsn":25696968,"xmin":null},"op":"c","ts_ms":1665511743121,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25698760\"]","schema":"public","table":"orderline","txId":4510,"lsn":25698760,"xmin":null},"op":"c","ts_ms":1665511743134,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25699672\"]","schema":"public","table":"orderline","txId":4510,"lsn":25699672,"xmin":null},"op":"c","ts_ms":1665511743134,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25700584\"]","schema":"public","table":"orderline","txId":4510,"lsn":25700584,"xmin":null},"op":"c","ts_ms":1665511743134,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25701488\"]","schema":"public","table":"orderline","txId":4510,"lsn":25701488,"xmin":null},"op":"c","ts_ms":1665511743135,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25702376\"]","schema":"public","table":"orderline","txId":4510,"lsn":25702376,"xmin":null},"op":"c","ts_ms":1665511743135,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3013,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25703952\"]","schema":"public","table":"orderline","txId":4511,"lsn":25703952,"xmin":null},"op":"c","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3013,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25704864\"]","schema":"public","table":"orderline","txId":4511,"lsn":25704864,"xmin":null},"op":"c","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3013,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25705776\"]","schema":"public","table":"orderline","txId":4511,"lsn":25705776,"xmin":null},"op":"c","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3013,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25706704\"]","schema":"public","table":"orderline","txId":4511,"lsn":25706704,"xmin":null},"op":"c","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3013,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25707592\"]","schema":"public","table":"orderline","txId":4511,"lsn":25707592,"xmin":null},"op":"c","ts_ms":1665511743159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3014,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25709168\"]","schema":"public","table":"orderline","txId":4512,"lsn":25709168,"xmin":null},"op":"c","ts_ms":1665511743179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3014,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25710168\"]","schema":"public","table":"orderline","txId":4512,"lsn":25710168,"xmin":null},"op":"c","ts_ms":1665511743179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3014,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25711080\"]","schema":"public","table":"orderline","txId":4512,"lsn":25711080,"xmin":null},"op":"c","ts_ms":1665511743180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3014,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25711984\"]","schema":"public","table":"orderline","txId":4512,"lsn":25711984,"xmin":null},"op":"c","ts_ms":1665511743180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3014,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25712872\"]","schema":"public","table":"orderline","txId":4512,"lsn":25712872,"xmin":null},"op":"c","ts_ms":1665511743180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3015,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25714448\"]","schema":"public","table":"orderline","txId":4513,"lsn":25714448,"xmin":null},"op":"c","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3015,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25715384\"]","schema":"public","table":"orderline","txId":4513,"lsn":25715384,"xmin":null},"op":"c","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3015,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25716296\"]","schema":"public","table":"orderline","txId":4513,"lsn":25716296,"xmin":null},"op":"c","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3015,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25717200\"]","schema":"public","table":"orderline","txId":4513,"lsn":25717200,"xmin":null},"op":"c","ts_ms":1665511743205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3015,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25718088\"]","schema":"public","table":"orderline","txId":4513,"lsn":25718088,"xmin":null},"op":"c","ts_ms":1665511743205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3016,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25719664\"]","schema":"public","table":"orderline","txId":4514,"lsn":25719664,"xmin":null},"op":"c","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3016,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25720672\"]","schema":"public","table":"orderline","txId":4514,"lsn":25720672,"xmin":null},"op":"c","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3016,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25721584\"]","schema":"public","table":"orderline","txId":4514,"lsn":25721584,"xmin":null},"op":"c","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3016,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25722488\"]","schema":"public","table":"orderline","txId":4514,"lsn":25722488,"xmin":null},"op":"c","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3016,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25723400\"]","schema":"public","table":"orderline","txId":4514,"lsn":25723400,"xmin":null},"op":"c","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3017,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25724976\"]","schema":"public","table":"orderline","txId":4515,"lsn":25724976,"xmin":null},"op":"c","ts_ms":1665511743250,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3017,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25725888\"]","schema":"public","table":"orderline","txId":4515,"lsn":25725888,"xmin":null},"op":"c","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3017,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25726800\"]","schema":"public","table":"orderline","txId":4515,"lsn":25726800,"xmin":null},"op":"c","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3017,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25727704\"]","schema":"public","table":"orderline","txId":4515,"lsn":25727704,"xmin":null},"op":"c","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3017,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25728592\"]","schema":"public","table":"orderline","txId":4515,"lsn":25728592,"xmin":null},"op":"c","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3018,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25730168\"]","schema":"public","table":"orderline","txId":4516,"lsn":25730168,"xmin":null},"op":"c","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3018,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25731200\"]","schema":"public","table":"orderline","txId":4516,"lsn":25731200,"xmin":null},"op":"c","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3018,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25732112\"]","schema":"public","table":"orderline","txId":4516,"lsn":25732112,"xmin":null},"op":"c","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3018,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25733016\"]","schema":"public","table":"orderline","txId":4516,"lsn":25733016,"xmin":null},"op":"c","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3018,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25733904\"]","schema":"public","table":"orderline","txId":4516,"lsn":25733904,"xmin":null},"op":"c","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3019,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25735480\"]","schema":"public","table":"orderline","txId":4517,"lsn":25735480,"xmin":null},"op":"c","ts_ms":1665511743358,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3019,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25736392\"]","schema":"public","table":"orderline","txId":4517,"lsn":25736392,"xmin":null},"op":"c","ts_ms":1665511743358,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3019,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25737304\"]","schema":"public","table":"orderline","txId":4517,"lsn":25737304,"xmin":null},"op":"c","ts_ms":1665511743358,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3019,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25738208\"]","schema":"public","table":"orderline","txId":4517,"lsn":25738208,"xmin":null},"op":"c","ts_ms":1665511743359,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3019,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25739096\"]","schema":"public","table":"orderline","txId":4517,"lsn":25739096,"xmin":null},"op":"c","ts_ms":1665511743359,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3020,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":101.850006,"ol_dist_info":"hSiR0KnowDKSPFDaoYDA6B4I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25740696\"]","schema":"public","table":"orderline","txId":4518,"lsn":25740696,"xmin":null},"op":"c","ts_ms":1665511743381,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3020,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":221.76,"ol_dist_info":"CGbiPwECriqUnhMufi0gPAS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25741704\"]","schema":"public","table":"orderline","txId":4518,"lsn":25741704,"xmin":null},"op":"c","ts_ms":1665511743381,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3020,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":537.32,"ol_dist_info":"9mRI4dAnfnvml5K8BAXZyyS7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25742616\"]","schema":"public","table":"orderline","txId":4518,"lsn":25742616,"xmin":null},"op":"c","ts_ms":1665511743382,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3020,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":718.16,"ol_dist_info":"ZQZRn5goNg3Swf5fyB6g4pTc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25743520\"]","schema":"public","table":"orderline","txId":4518,"lsn":25743520,"xmin":null},"op":"c","ts_ms":1665511743382,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3020,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":625.41,"ol_dist_info":"TGNxEYtbQspqYFMyIcR5NPgK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25744408\"]","schema":"public","table":"orderline","txId":4518,"lsn":25744408,"xmin":null},"op":"c","ts_ms":1665511743382,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3021,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25745984\"]","schema":"public","table":"orderline","txId":4519,"lsn":25745984,"xmin":null},"op":"c","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3021,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25755080\"]","schema":"public","table":"orderline","txId":4519,"lsn":25755080,"xmin":null},"op":"c","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3021,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25756152\"]","schema":"public","table":"orderline","txId":4519,"lsn":25756152,"xmin":null},"op":"c","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3021,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25757168\"]","schema":"public","table":"orderline","txId":4519,"lsn":25757168,"xmin":null},"op":"c","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3021,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25758184\"]","schema":"public","table":"orderline","txId":4519,"lsn":25758184,"xmin":null},"op":"c","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3022,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25759952\"]","schema":"public","table":"orderline","txId":4520,"lsn":25759952,"xmin":null},"op":"c","ts_ms":1665511743427,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3022,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25760936\"]","schema":"public","table":"orderline","txId":4520,"lsn":25760936,"xmin":null},"op":"c","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3022,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25761856\"]","schema":"public","table":"orderline","txId":4520,"lsn":25761856,"xmin":null},"op":"c","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3022,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25762744\"]","schema":"public","table":"orderline","txId":4520,"lsn":25762744,"xmin":null},"op":"c","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3022,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25763632\"]","schema":"public","table":"orderline","txId":4520,"lsn":25763632,"xmin":null},"op":"c","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3023,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25765232\"]","schema":"public","table":"orderline","txId":4521,"lsn":25765232,"xmin":null},"op":"c","ts_ms":1665511743449,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3023,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25766208\"]","schema":"public","table":"orderline","txId":4521,"lsn":25766208,"xmin":null},"op":"c","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3023,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25767128\"]","schema":"public","table":"orderline","txId":4521,"lsn":25767128,"xmin":null},"op":"c","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3023,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25768016\"]","schema":"public","table":"orderline","txId":4521,"lsn":25768016,"xmin":null},"op":"c","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3023,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25768904\"]","schema":"public","table":"orderline","txId":4521,"lsn":25768904,"xmin":null},"op":"c","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3024,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25770480\"]","schema":"public","table":"orderline","txId":4522,"lsn":25770480,"xmin":null},"op":"c","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3024,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25771464\"]","schema":"public","table":"orderline","txId":4522,"lsn":25771464,"xmin":null},"op":"c","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3024,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25772408\"]","schema":"public","table":"orderline","txId":4522,"lsn":25772408,"xmin":null},"op":"c","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3024,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25773296\"]","schema":"public","table":"orderline","txId":4522,"lsn":25773296,"xmin":null},"op":"c","ts_ms":1665511743472,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3024,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25774184\"]","schema":"public","table":"orderline","txId":4522,"lsn":25774184,"xmin":null},"op":"c","ts_ms":1665511743472,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3025,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25775760\"]","schema":"public","table":"orderline","txId":4523,"lsn":25775760,"xmin":null},"op":"c","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3025,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25776744\"]","schema":"public","table":"orderline","txId":4523,"lsn":25776744,"xmin":null},"op":"c","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3025,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25777664\"]","schema":"public","table":"orderline","txId":4523,"lsn":25777664,"xmin":null},"op":"c","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3025,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25778552\"]","schema":"public","table":"orderline","txId":4523,"lsn":25778552,"xmin":null},"op":"c","ts_ms":1665511743496,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3025,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25779440\"]","schema":"public","table":"orderline","txId":4523,"lsn":25779440,"xmin":null},"op":"c","ts_ms":1665511743496,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3026,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25781040\"]","schema":"public","table":"orderline","txId":4524,"lsn":25781040,"xmin":null},"op":"c","ts_ms":1665511743515,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3026,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25782024\"]","schema":"public","table":"orderline","txId":4524,"lsn":25782024,"xmin":null},"op":"c","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3026,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25782944\"]","schema":"public","table":"orderline","txId":4524,"lsn":25782944,"xmin":null},"op":"c","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3026,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25783832\"]","schema":"public","table":"orderline","txId":4524,"lsn":25783832,"xmin":null},"op":"c","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3026,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25784720\"]","schema":"public","table":"orderline","txId":4524,"lsn":25784720,"xmin":null},"op":"c","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3027,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25786296\"]","schema":"public","table":"orderline","txId":4525,"lsn":25786296,"xmin":null},"op":"c","ts_ms":1665511743534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3027,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25787280\"]","schema":"public","table":"orderline","txId":4525,"lsn":25787280,"xmin":null},"op":"c","ts_ms":1665511743534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3027,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25788200\"]","schema":"public","table":"orderline","txId":4525,"lsn":25788200,"xmin":null},"op":"c","ts_ms":1665511743535,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3027,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25789112\"]","schema":"public","table":"orderline","txId":4525,"lsn":25789112,"xmin":null},"op":"c","ts_ms":1665511743535,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3027,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25790000\"]","schema":"public","table":"orderline","txId":4525,"lsn":25790000,"xmin":null},"op":"c","ts_ms":1665511743535,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3028,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25791576\"]","schema":"public","table":"orderline","txId":4526,"lsn":25791576,"xmin":null},"op":"c","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3028,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25792560\"]","schema":"public","table":"orderline","txId":4526,"lsn":25792560,"xmin":null},"op":"c","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3028,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25793480\"]","schema":"public","table":"orderline","txId":4526,"lsn":25793480,"xmin":null},"op":"c","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3028,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25794368\"]","schema":"public","table":"orderline","txId":4526,"lsn":25794368,"xmin":null},"op":"c","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3028,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25795256\"]","schema":"public","table":"orderline","txId":4526,"lsn":25795256,"xmin":null},"op":"c","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3029,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25796856\"]","schema":"public","table":"orderline","txId":4527,"lsn":25796856,"xmin":null},"op":"c","ts_ms":1665511743570,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3029,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25797840\"]","schema":"public","table":"orderline","txId":4527,"lsn":25797840,"xmin":null},"op":"c","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3029,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25798760\"]","schema":"public","table":"orderline","txId":4527,"lsn":25798760,"xmin":null},"op":"c","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3029,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25799648\"]","schema":"public","table":"orderline","txId":4527,"lsn":25799648,"xmin":null},"op":"c","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3029,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25800536\"]","schema":"public","table":"orderline","txId":4527,"lsn":25800536,"xmin":null},"op":"c","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3030,"ol_d_id":2,"ol_w_id":1,"ol_number":0,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":483.55,"ol_dist_info":"FpUY1GK6eLYSTHIDVez1nUxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25802112\"]","schema":"public","table":"orderline","txId":4528,"lsn":25802112,"xmin":null},"op":"c","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3030,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":236.40001,"ol_dist_info":"02j0XPbpm5HRFBgadJ2bgHAB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25803096\"]","schema":"public","table":"orderline","txId":4528,"lsn":25803096,"xmin":null},"op":"c","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3030,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":123.69,"ol_dist_info":"VQqpPnvxwqwEgb8HbXkqJ1fc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25804016\"]","schema":"public","table":"orderline","txId":4528,"lsn":25804016,"xmin":null},"op":"c","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3030,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":80.24,"ol_dist_info":"pureWczDXLiX205i6ipmP47x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25804928\"]","schema":"public","table":"orderline","txId":4528,"lsn":25804928,"xmin":null},"op":"c","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3030,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":311.31,"ol_dist_info":"klH8VQQo8TLHdJnIXAyNlWVC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25805816\"]","schema":"public","table":"orderline","txId":4528,"lsn":25805816,"xmin":null},"op":"c","ts_ms":1665511743594,"transaction":null}} diff --git a/scripts/source/test_data/tpcc_orders.1 b/scripts/source/test_data/orders.1 similarity index 53% rename from scripts/source/test_data/tpcc_orders.1 rename to scripts/source/test_data/orders.1 index 76b10fda6ab2d..aebf7fd719b73 100644 --- a/scripts/source/test_data/tpcc_orders.1 +++ b/scripts/source/test_data/orders.1 @@ -1,107 +1,180 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":1,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":2,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":3,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":4,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":5,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":6,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":7,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":8,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":9,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":10,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":1,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":2,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":3,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":4,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":5,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081207,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":6,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081207,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":7,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":8,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":9,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":10,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":1,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":2,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":3,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":4,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":5,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":6,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":7,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":8,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":9,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":10,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":1,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":2,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":3,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":4,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":5,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":6,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":7,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":8,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":9,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":10,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":1,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":2,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":3,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":4,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":5,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":6,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":7,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":8,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":9,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":10,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":2,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":3,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":4,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":5,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":6,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":7,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081208,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081208,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":8,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":9,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":10,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":2,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":3,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":4,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":5,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":6,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":7,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":8,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":9,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":10,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":2,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":3,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":4,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":5,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":6,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":7,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":8,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":9,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":10,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":2,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":3,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":4,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":5,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":6,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":7,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":8,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":9,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":10,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":2,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":3,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":4,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":5,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":6,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":7,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":8,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":9,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":10,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":13,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081209,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orders","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081209,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2105,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2105,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24363872\"]","schema":"public","table":"orders","txId":1325,"lsn":24363872,"xmin":null},"op":"u","ts_ms":1664141081508,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2106,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2106,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24411016\"]","schema":"public","table":"orders","txId":1326,"lsn":24411016,"xmin":null},"op":"u","ts_ms":1664141081520,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2107,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2107,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24414216\"]","schema":"public","table":"orders","txId":1327,"lsn":24414216,"xmin":null},"op":"u","ts_ms":1664141081522,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2108,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2108,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24434072\"]","schema":"public","table":"orders","txId":1328,"lsn":24434072,"xmin":null},"op":"u","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2109,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2109,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24454160\"]","schema":"public","table":"orders","txId":1329,"lsn":24454160,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3011,"o_d_id":2,"o_w_id":1,"o_c_id":2,"o_entry_d":"2022-09-25 21:24:41.478415+00","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24469744\"]","schema":"public","table":"orders","txId":1330,"lsn":24469744,"xmin":null},"op":"c","ts_ms":1664141081529,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3012,"o_d_id":2,"o_w_id":1,"o_c_id":2,"o_entry_d":"2022-09-25 21:24:41.482301+00","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24493016\"]","schema":"public","table":"orders","txId":1331,"lsn":24493016,"xmin":null},"op":"c","ts_ms":1664141081534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":1,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":2,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":3,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":4,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":5,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":6,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":7,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":8,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":9,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":1,"o_d_id":10,"o_w_id":1,"o_c_id":1,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":1,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":2,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":3,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":4,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":5,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":6,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":7,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":8,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":9,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2,"o_d_id":10,"o_w_id":1,"o_c_id":2,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":1,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":2,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":3,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":4,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":5,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":6,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":7,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":8,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":9,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3,"o_d_id":10,"o_w_id":1,"o_c_id":3,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":1,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":2,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":3,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":4,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":5,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":6,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":7,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":8,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":9,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":4,"o_d_id":10,"o_w_id":1,"o_c_id":4,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":1,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":2,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":3,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":4,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":5,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":6,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":7,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":8,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":9,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":5,"o_d_id":10,"o_w_id":1,"o_c_id":5,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":2,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":3,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":4,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":5,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":6,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":7,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":8,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":9,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2114,"o_d_id":10,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":2,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":3,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":4,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":5,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":6,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":7,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":8,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":9,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2113,"o_d_id":10,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":2,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":3,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":4,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":5,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":6,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":7,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":8,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":9,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2112,"o_d_id":10,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":2,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739225,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739225,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":3,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":4,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":5,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":6,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":7,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":8,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":9,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2111,"o_d_id":10,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":2,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":3,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":4,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":5,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":6,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":7,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":8,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":9,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2110,"o_d_id":10,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":13,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":2,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":3,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":4,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":5,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":6,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":7,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":8,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":9,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2109,"o_d_id":10,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":2,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":3,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":4,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":5,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":6,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":7,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":8,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":9,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2108,"o_d_id":10,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":2,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":3,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":4,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":5,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":6,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":7,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":8,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":9,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2107,"o_d_id":10,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":2,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":3,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":4,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":5,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":6,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":7,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":8,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":9,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2106,"o_d_id":10,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":2,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":6,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":3,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":7,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":4,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":8,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":5,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":9,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":6,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":7,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":8,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":11,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":9,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":12,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":2105,"o_d_id":10,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":13,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739226,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"orders","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739226,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2105,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2105,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":1,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511742993,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"25502840\"]","schema":"public","table":"orders","txId":4499,"lsn":25502840,"xmin":null},"op":"u","ts_ms":1665511743063,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2106,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2106,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743006,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25544056\",\"25544056\"]","schema":"public","table":"orders","txId":4500,"lsn":25544056,"xmin":null},"op":"u","ts_ms":1665511743078,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2107,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2107,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":3,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743015,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25547032\",\"25547032\"]","schema":"public","table":"orders","txId":4501,"lsn":25547032,"xmin":null},"op":"u","ts_ms":1665511743080,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2108,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2108,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743024,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25566824\",\"25566824\"]","schema":"public","table":"orders","txId":4502,"lsn":25566824,"xmin":null},"op":"u","ts_ms":1665511743082,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2109,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2109,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743034,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25586848\",\"25595088\"]","schema":"public","table":"orders","txId":4503,"lsn":25595088,"xmin":null},"op":"u","ts_ms":1665511743083,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2110,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":4,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2110,"o_d_id":1,"o_w_id":1,"o_c_id":10,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743043,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25610240\",\"25610296\"]","schema":"public","table":"orders","txId":4504,"lsn":25610296,"xmin":null},"op":"u","ts_ms":1665511743084,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2111,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2111,"o_d_id":1,"o_w_id":1,"o_c_id":9,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":7,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743053,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25628840\",\"25628904\"]","schema":"public","table":"orders","txId":4505,"lsn":25628904,"xmin":null},"op":"u","ts_ms":1665511743086,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2112,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":6,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2112,"o_d_id":1,"o_w_id":1,"o_c_id":8,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":8,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743062,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25640584\",\"25640648\"]","schema":"public","table":"orders","txId":4506,"lsn":25640648,"xmin":null},"op":"u","ts_ms":1665511743087,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2113,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":2,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2113,"o_d_id":1,"o_w_id":1,"o_c_id":7,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":9,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743071,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25643696\",\"25643760\"]","schema":"public","table":"orders","txId":4507,"lsn":25643760,"xmin":null},"op":"u","ts_ms":1665511743088,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":{"o_id":2114,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":5,"o_ol_cnt":5,"o_all_local":1},"after":{"o_id":2114,"o_d_id":1,"o_w_id":1,"o_c_id":6,"o_entry_d":"2015-11-22 00:00:00","o_carrier_id":10,"o_ol_cnt":5,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743081,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25655464\",\"25655528\"]","schema":"public","table":"orders","txId":4508,"lsn":25655528,"xmin":null},"op":"u","ts_ms":1665511743089,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3011,"o_d_id":2,"o_w_id":1,"o_c_id":1,"o_entry_d":"2022-10-11 18:09:03.084829","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25671880\"]","schema":"public","table":"orders","txId":4509,"lsn":25671880,"xmin":null},"op":"c","ts_ms":1665511743115,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3012,"o_d_id":2,"o_w_id":1,"o_c_id":2,"o_entry_d":"2022-10-11 18:09:03.10888","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25698512\"]","schema":"public","table":"orders","txId":4510,"lsn":25698512,"xmin":null},"op":"c","ts_ms":1665511743134,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3013,"o_d_id":2,"o_w_id":1,"o_c_id":3,"o_entry_d":"2022-10-11 18:09:03.133535","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25703768\"]","schema":"public","table":"orders","txId":4511,"lsn":25703768,"xmin":null},"op":"c","ts_ms":1665511743157,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3014,"o_d_id":2,"o_w_id":1,"o_c_id":4,"o_entry_d":"2022-10-11 18:09:03.156298","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25708984\"]","schema":"public","table":"orders","txId":4512,"lsn":25708984,"xmin":null},"op":"c","ts_ms":1665511743179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3015,"o_d_id":2,"o_w_id":1,"o_c_id":5,"o_entry_d":"2022-10-11 18:09:03.179062","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25714264\"]","schema":"public","table":"orders","txId":4513,"lsn":25714264,"xmin":null},"op":"c","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3016,"o_d_id":2,"o_w_id":1,"o_c_id":6,"o_entry_d":"2022-10-11 18:09:03.204205","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25719480\"]","schema":"public","table":"orders","txId":4514,"lsn":25719480,"xmin":null},"op":"c","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3017,"o_d_id":2,"o_w_id":1,"o_c_id":7,"o_entry_d":"2022-10-11 18:09:03.226772","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25724792\"]","schema":"public","table":"orders","txId":4515,"lsn":25724792,"xmin":null},"op":"c","ts_ms":1665511743250,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3018,"o_d_id":2,"o_w_id":1,"o_c_id":8,"o_entry_d":"2022-10-11 18:09:03.250607","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25729984\"]","schema":"public","table":"orders","txId":4516,"lsn":25729984,"xmin":null},"op":"c","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3019,"o_d_id":2,"o_w_id":1,"o_c_id":9,"o_entry_d":"2022-10-11 18:09:03.330918","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25735296\"]","schema":"public","table":"orders","txId":4517,"lsn":25735296,"xmin":null},"op":"c","ts_ms":1665511743358,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3020,"o_d_id":2,"o_w_id":1,"o_c_id":10,"o_entry_d":"2022-10-11 18:09:03.358011","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25740512\"]","schema":"public","table":"orders","txId":4518,"lsn":25740512,"xmin":null},"op":"c","ts_ms":1665511743381,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3021,"o_d_id":2,"o_w_id":1,"o_c_id":1,"o_entry_d":"2022-10-11 18:09:03.381578","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25745800\"]","schema":"public","table":"orders","txId":4519,"lsn":25745800,"xmin":null},"op":"c","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3022,"o_d_id":2,"o_w_id":1,"o_c_id":2,"o_entry_d":"2022-10-11 18:09:03.403741","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25759704\"]","schema":"public","table":"orders","txId":4520,"lsn":25759704,"xmin":null},"op":"c","ts_ms":1665511743427,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3023,"o_d_id":2,"o_w_id":1,"o_c_id":3,"o_entry_d":"2022-10-11 18:09:03.426918","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25765048\"]","schema":"public","table":"orders","txId":4521,"lsn":25765048,"xmin":null},"op":"c","ts_ms":1665511743449,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3024,"o_d_id":2,"o_w_id":1,"o_c_id":4,"o_entry_d":"2022-10-11 18:09:03.449726","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25770296\"]","schema":"public","table":"orders","txId":4522,"lsn":25770296,"xmin":null},"op":"c","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3025,"o_d_id":2,"o_w_id":1,"o_c_id":5,"o_entry_d":"2022-10-11 18:09:03.471114","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25775576\"]","schema":"public","table":"orders","txId":4523,"lsn":25775576,"xmin":null},"op":"c","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3026,"o_d_id":2,"o_w_id":1,"o_c_id":6,"o_entry_d":"2022-10-11 18:09:03.495396","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25780856\"]","schema":"public","table":"orders","txId":4524,"lsn":25780856,"xmin":null},"op":"c","ts_ms":1665511743515,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3027,"o_d_id":2,"o_w_id":1,"o_c_id":7,"o_entry_d":"2022-10-11 18:09:03.515557","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25786112\"]","schema":"public","table":"orders","txId":4525,"lsn":25786112,"xmin":null},"op":"c","ts_ms":1665511743534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3028,"o_d_id":2,"o_w_id":1,"o_c_id":8,"o_entry_d":"2022-10-11 18:09:03.534517","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25791392\"]","schema":"public","table":"orders","txId":4526,"lsn":25791392,"xmin":null},"op":"c","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3029,"o_d_id":2,"o_w_id":1,"o_c_id":9,"o_entry_d":"2022-10-11 18:09:03.552724","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25796672\"]","schema":"public","table":"orders","txId":4527,"lsn":25796672,"xmin":null},"op":"c","ts_ms":1665511743570,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"o_id"},{"type":"int32","optional":false,"field":"o_d_id"},{"type":"int32","optional":false,"field":"o_w_id"},{"type":"int32","optional":true,"field":"o_c_id"},{"type":"string","optional":true,"field":"o_entry_d"},{"type":"int32","optional":true,"field":"o_carrier_id"},{"type":"int32","optional":true,"field":"o_ol_cnt"},{"type":"int32","optional":true,"field":"o_all_local"}],"optional":true,"name":"postgres.public.orders.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orders.Envelope"},"payload":{"before":null,"after":{"o_id":3030,"o_d_id":2,"o_w_id":1,"o_c_id":10,"o_entry_d":"2022-10-11 18:09:03.570662","o_carrier_id":null,"o_ol_cnt":10,"o_all_local":1},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25801928\"]","schema":"public","table":"orders","txId":4528,"lsn":25801928,"xmin":null},"op":"c","ts_ms":1665511743594,"transaction":null}} diff --git a/scripts/source/test_data/stock.1 b/scripts/source/test_data/stock.1 new file mode 100644 index 0000000000000..4adc627e872c7 --- /dev/null +++ b/scripts/source/test_data/stock.1 @@ -0,0 +1,1601 @@ +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1,"st_w_id":1,"st_quantity":43,"st_dist_01":"FaaD5wv72I8cQ6ZN1AsbLKux","st_dist_02":"zrrCUFUDjIj6yTbuogTEBjlt","st_dist_03":"fP1dC0DOwSYOgWXgjfM0cDT1","st_dist_04":"Tz7nM6h3EgRRL8ulnw4tVTMt","st_dist_05":"0UacyTVP9hBB3kVMljj2QpNJ","st_dist_06":"KITLomsSFuYfBTErokVZoMjc","st_dist_07":"nbDUonBGyfYSAEz0uCfVvNy1","st_dist_08":"tJKhhHFajdnH8Mqkyh9JKVSa","st_dist_09":"LUNxkDkr38bQAlskCmQDQgZQ","st_dist_10":"812bHfTapxCwJyC9hdPBhxxk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lLqSXHTUyCRzDvWiF32Ov8b5d8AcWQOaquZYqRXtbWJP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":2,"st_w_id":1,"st_quantity":24,"st_dist_01":"Sqin429SdslAwZzDv1kuZiwm","st_dist_02":"ZzuDymBQleimE4XsAZNVUBbK","st_dist_03":"2EDTiw1SknFSitdoAor8iXCr","st_dist_04":"f6wk9hKJb8uKobaLOsZzyxYQ","st_dist_05":"c0563DlqWlz1kdzchCzBq81t","st_dist_06":"M3rf5nXwQycUpszD6P23cWEH","st_dist_07":"abXWrGXCX9Om9tpdaZrjJB94","st_dist_08":"pJwvLyhJCsrUgWv3u6qv8td5","st_dist_09":"N1aBZlaWtGVXzdttry2z0MQ5","st_dist_10":"Wiwev1tu1FuLIP2rVnoyeFSh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eD6gwuVwBaOxAHkBihJk2YGbiyrxu6ASUt4u1O660UPtbHIu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":3,"st_w_id":1,"st_quantity":48,"st_dist_01":"djQtnHHokL4wFDl9QvE4rzNi","st_dist_02":"9tPhz3CLht3bnGbT2l25LYwV","st_dist_03":"lkvvK637TKRQuMfaxIidsLGW","st_dist_04":"3DFG91gvZcEodyYUkb5kP0Ha","st_dist_05":"WEagtH9yMIjJ7dg2wAdw0wM4","st_dist_06":"vUnfVWNhDFf9xGdz9KUeQCNO","st_dist_07":"FGi2A8YTH3CMkDhxqcat1qhl","st_dist_08":"Qxv4F0xF6Q4ojaQ9pPKIr9mW","st_dist_09":"g7AZNAOgAsEr7lzaxhyW2XG0","st_dist_10":"fl4EWAS5hG3QyT2164yzXg2L","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7a9uDIJRzFWwi70H1qUZlR1nLAh7syp3etTwmgbCwQfiL23"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":4,"st_w_id":1,"st_quantity":17,"st_dist_01":"ijjPHT1oskmL20pP0WYqOUBr","st_dist_02":"dCj9ly66H5QwswTagweydpmi","st_dist_03":"Ce0u7ivOUC0ITn0Q1t32pXHk","st_dist_04":"hej9D8HscOViPlGeYhp32au4","st_dist_05":"ft5nGms6iWUjWZROYUwrOJs1","st_dist_06":"z6xtJvyt8VGlLUZbExsvev8Z","st_dist_07":"TXVTBVR1SPMHCtdJCFqTxZtV","st_dist_08":"c9KNkwws4kViuia73jrEDaWC","st_dist_09":"QCfK7cJVVxiAFyc57pe00ZGc","st_dist_10":"8EcluX4kdwUQf8885jqSYGzf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mRfhmzOTLPxv7keqZObWHY2H29829Sto0EWw8h9cyLEDjAu5Bn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":5,"st_w_id":1,"st_quantity":66,"st_dist_01":"Z20xV0lub0gAFVXXMjKFF4hr","st_dist_02":"YeOJXRIISEqHzQHqJsmRhCJF","st_dist_03":"wnhBMft37DnPVoJ2fKkzbygY","st_dist_04":"dlvxDEB6FhhMrh0Bz9NtuIx2","st_dist_05":"LPUSFRh0WQddLdwGzan4Zc78","st_dist_06":"fuMH6FYOo84dXwwYREvKMUwJ","st_dist_07":"BXRC0ABRN5ZqS443KxSxXRL7","st_dist_08":"khNBoM5omT88Uc6JBtTwdUd3","st_dist_09":"99zs1wTHeffjKXFraHrcU3HK","st_dist_10":"9IKiGzAr2yx7BSktat15auRF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8DyPWrP5xmZktuCnCgcBEm3N4k5KsJcN0hP0RUPKBWNLdisWDu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":6,"st_w_id":1,"st_quantity":60,"st_dist_01":"vHnHBujOQO5vS1xSvbofw6Gm","st_dist_02":"WncPXIzb0tIYwpQ99jZU4zLH","st_dist_03":"kDaVGrh1xguvcmlCGvDmx2aG","st_dist_04":"S0r4TuN2YhXup3HgTKVcmg7M","st_dist_05":"z7vzu0aAy4R4S68rBVEEstkT","st_dist_06":"osqh3V0Xper25xJswYLhXAKe","st_dist_07":"7jnmzQ8r2ndxcFN5bsiJdash","st_dist_08":"JLTz6WkaBuuriQYwTuwJ9z8d","st_dist_09":"81oDHDwxDlmkUTzKJflGFzsO","st_dist_10":"vMeXfoMdJNOwrLdW0UwCyeOX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Bth4GW6by525YdrsSt1GlvLXgqCbK1uKD7Kl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":7,"st_w_id":1,"st_quantity":57,"st_dist_01":"tlcN73AfRkg2U0uMVJJBxY3s","st_dist_02":"uUhwWaEpF4UjRNnUYgBtzCqr","st_dist_03":"IZAEBzpTKhdd14PJehq3Hjqj","st_dist_04":"ZXEWb0Bzvafi5DstlPkHQgN2","st_dist_05":"rL94OLXolwRWLGEPxVPlDMvJ","st_dist_06":"oxflL5qqeR0mUz3J7ajugRK3","st_dist_07":"PbjPtlNyJ6DEDByWICSOENTq","st_dist_08":"dQx7VLavsuBvXgy8siDjI3eQ","st_dist_09":"8Pp60547s65cTeQ3cflTTw7i","st_dist_10":"19IdRvFp4dc9ClSU2LZbAPN9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CZAiYI484gceZ0BpiJtT06uMOz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":8,"st_w_id":1,"st_quantity":28,"st_dist_01":"Nu9zJkrAcYdXXeaHWJC2nQME","st_dist_02":"GU2VaJgNFoMsmjq53Lknp570","st_dist_03":"EoDvkcWYahHgISiMfvtTKQPd","st_dist_04":"e4fdIiKIvBQo1FMJumF9D25G","st_dist_05":"ftvNk4c77wfZ9PVzTQZHrIrJ","st_dist_06":"0HdOLKR6kpguDPfeTmRcOXws","st_dist_07":"s1CeezomdokuK7k0tA8eyAzP","st_dist_08":"ORkFmLvVupJ65Ml9OoOQO9Gs","st_dist_09":"LSBaYL30FhLixIUj6MiS7gYM","st_dist_10":"pFNhreapK8FDN1ezeLa4TozY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UmMCYVXmDx2xBsEDS7m31A07QP8NHLko4x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":9,"st_w_id":1,"st_quantity":25,"st_dist_01":"7dYvYdBTydchnumb0Sq03tvQ","st_dist_02":"JLANJfkfHiY4EQkrX8A0imkm","st_dist_03":"gsi1RqRl1LF95Ra7FPENatZ9","st_dist_04":"FJBaRzmajY6LLFdUuoIsK7sY","st_dist_05":"t3qnxISLRYbuJmEidSqBDOF1","st_dist_06":"ffh6DjgBlP0gIqjjVitqPSAu","st_dist_07":"mIOIQkGmoP6U2sxo6FLDebh5","st_dist_08":"1LrjzpM78JGzcROENJoW8Ea5","st_dist_09":"vPCyTYFOmlrQHqcGh2UOLnHu","st_dist_10":"gaoOwLnKZ8Et7omt1OcP3q41","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SuyukmmJs6yJgEv1UtIBo9XoDu5WqfqnTX7HcIKwk9MRisKkg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":10,"st_w_id":1,"st_quantity":87,"st_dist_01":"HEXjOPPIxILVkVAOLc3x5Mvp","st_dist_02":"yl8b1qgL6Y6lJ5Z5ZkI3T2W5","st_dist_03":"sI4WHRgODhHJe5N4SZ4vEdjc","st_dist_04":"92vAd0Lyd2Bb8m6yTLbv2Pmp","st_dist_05":"Z2dkVFpwR9l0GnJt4M9tmv6v","st_dist_06":"lSpmtEHMWHRUyupfEZfe3SWW","st_dist_07":"17eT8lasMCOWtzRaSvtRhU9c","st_dist_08":"se2cAcfdAmlCVJzPXSroi7bI","st_dist_09":"8Ou9vLPH37cGadcRHPDHd1Ve","st_dist_10":"HPCKocoPsoDyHZc5S1gpPnqo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NTT3qShrTXOon0TMaMZRNp1U8Cm3CKR5ffu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":11,"st_w_id":1,"st_quantity":49,"st_dist_01":"OgGptsRE5QeasxBWLac62etx","st_dist_02":"eQbb6a2q0mjwwz2N6eI4ZV2U","st_dist_03":"lbiNUVmK58uDVPHhvODlRlCH","st_dist_04":"7UQZxS4ts9aL8xz1LXazKWtB","st_dist_05":"hsHwH3hlEKsPVQiAACy8VkrO","st_dist_06":"5xPQlAHdkrJi6si9FATOCRp8","st_dist_07":"NCThMuc8aHpprb5WSdMSSdMM","st_dist_08":"I5MmB4RAfS1WVcgQthQDvtmH","st_dist_09":"obgT0QWgAfHBOvAlZSiHmXra","st_dist_10":"pyfIUCebCziqqCrjMUJydTDv","st_ytd":0,"st_order_cnt":42,"st_remote_cnt":0,"st_data":"32bmgekf7SO8L1gRpRh3lESVQ0chl2aYJP2c"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":12,"st_w_id":1,"st_quantity":64,"st_dist_01":"Ikwx5iSBTAKH4fHvBBkMCz1K","st_dist_02":"NmHKrAi6PhjxBlMnsxr7Ejbr","st_dist_03":"2UdoW7J4YqDfKJ4p5jQZ3Z0f","st_dist_04":"jE1ZmjHxM3MeanhXsTdPLlvt","st_dist_05":"lEqwZAWvBMBzhmxJOEVOXlxF","st_dist_06":"p8Ir0MzA6kq1rC2ScAjfAf5r","st_dist_07":"53Xy6PXHkmTdyVuijpDD9y7z","st_dist_08":"G8SRJ9PfuIiC8UTST5Dt3XGb","st_dist_09":"JZlucyiLRO7OLIUL98N5lnTi","st_dist_10":"2iEAPFcaOWOiuQHb1llAQs24","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5sf2NwiAQLiXwcHkg1utmqKCpepMfO1Yn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":13,"st_w_id":1,"st_quantity":17,"st_dist_01":"gC3xOUQjedJIClpiGubgnKUt","st_dist_02":"n4nwxc6MkkDu1gp21b876d33","st_dist_03":"umR27GQLpzqFaPmAUjl3cG64","st_dist_04":"FBK84UI5Cs6p1gmdTRKFvyFh","st_dist_05":"dFkBbSPdVm4mzLqxovETwnrl","st_dist_06":"XIYfMtbETyl9OGpgLjixjsYh","st_dist_07":"yaqp0QvNpBIfO3oaTjnIIv9a","st_dist_08":"oTYcX6kvR10mYkaMjxKsGSAz","st_dist_09":"VRYOsrFDYICNIKhQ2zFwuPq9","st_dist_10":"KsDy9Oh5XGdeL53eoLy0Wact","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yZvT4o6emANjX22hRcPtb8KWbJ0E"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":14,"st_w_id":1,"st_quantity":86,"st_dist_01":"9GJAw1Wc1k3pFLy8fqRtIBwf","st_dist_02":"j2jGLh01MLmegTpUg1cI34yD","st_dist_03":"BeIvKwh4jnYDpsv6SxTbjhRY","st_dist_04":"mCChXiW7YN52frfdcKDJQzYp","st_dist_05":"fIqRsqEuKjE8whwt4ujkP18e","st_dist_06":"hWAtll6Cq9fSDFaUxPO6uxHH","st_dist_07":"tk7jtFbdgsTUChwV3aTf7hGj","st_dist_08":"JpekcrVBnzZIbEnqTQgnVqFd","st_dist_09":"oPU33HQU6JAi8RBpxXdMXqsh","st_dist_10":"mXUkApU9MNREU6HvjKk9mZMS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"M4dW5Iur2JObGk3MWK1joeGbdolYaeB8wEmF9iAlZI2pr0xMGN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":15,"st_w_id":1,"st_quantity":34,"st_dist_01":"xB2AIoqGjqo7XXyNxiLwJ3ds","st_dist_02":"NWXI9Yez3zTpI0tMlW6lDJDi","st_dist_03":"YzdHQOcrBDhXvGVO7olYbYdb","st_dist_04":"WglcN8ImYdZsqH3GS4YyBGrs","st_dist_05":"yPwgiW8hOaIySwh9zvfL4kvW","st_dist_06":"SffAUzBZCtMJoO6TFjaHoL3V","st_dist_07":"DtjpMpSYKKtkfm9IT9UDCoZZ","st_dist_08":"CJIjZvg5KjpcOzQVnJTqez3A","st_dist_09":"wkMQOz10jvyEQutw31vk0mkw","st_dist_10":"Q9hj18e8vkO8rCSFWjHE0tk5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sWv2nKaM78SxL5xJD6e0ThekQrx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":16,"st_w_id":1,"st_quantity":62,"st_dist_01":"27b6Zf7JFb1SmdZXDTVPoQgC","st_dist_02":"yOMA60seLr6dBi5q2xfBUCnm","st_dist_03":"hpe2OjrA9QLpKGxxmQdhbUsk","st_dist_04":"ZStK85oLDauW4kZ6aZ4Fu9S1","st_dist_05":"clWuvYOZvlytxQQFLBcRpXQ3","st_dist_06":"S2FrzqLz150rtaaXM8h1GtI5","st_dist_07":"p9eqfNxdd1dE2fJTVXeL0z5l","st_dist_08":"KlKqkHtlkTi4wxksrw3nVSPp","st_dist_09":"FAMfWQ63adL8qgpGOs6vECFx","st_dist_10":"T54wTmA2wnODLXADK1ocv5MZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DgGIk3swX0MLdtA4iVOlsdEUTS1p3jX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739233,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739233,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":17,"st_w_id":1,"st_quantity":31,"st_dist_01":"GV11Ikxz0eaD3GuMDVNXgyHa","st_dist_02":"DE9nrtzTFHYX3A9o0w2kmT7H","st_dist_03":"mGa8NYqgaiswZ82hWhkbhT0P","st_dist_04":"WDGHxT7guif2gnhCaJdPsdYC","st_dist_05":"NQvKRISY8TaryA66L8jQ5UvR","st_dist_06":"Q9VoWKXQA9WDVLsEPzSmsZSv","st_dist_07":"t6ryKdL7oFq2gnKFAc3nBPGp","st_dist_08":"KrOQN4pN0ws16daSYi8i1dSv","st_dist_09":"kfeUaQZ976pvnTS0dOAYLwfI","st_dist_10":"eRC73vErIlj30Rxu9yB5Fz8j","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AOcQRcrsWm9GtcynD9RxmfakGHlmrmr4BJSjmhFlBikiKt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":18,"st_w_id":1,"st_quantity":37,"st_dist_01":"HzLOpsuX3N3r1XoRMGlvKw5i","st_dist_02":"otqfJbWJqUobmxqZLxdrfILn","st_dist_03":"V1MsYDXK32Yme33N1UFSwFV0","st_dist_04":"xMi0C0rMelt3SnoW1QWLbjcW","st_dist_05":"yOsZ7cmSNyOVw59ueDzK1cxu","st_dist_06":"mxHphScT1kFZK2tyqXB2QWQn","st_dist_07":"fyWaIECb3Z7yE4DTSBXsAR38","st_dist_08":"0R1WEqna7ZS0301nORXRmJ7t","st_dist_09":"vyADRKEXfR7gxXaHytV3YwTI","st_dist_10":"s3EdLq5umz6OPJ3ulpXYspbQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BYszDYlJ0PmPhLgMXAyocFJxnbu28pqrXGpuF61h49s1lL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":19,"st_w_id":1,"st_quantity":24,"st_dist_01":"qslPHINjenFmFhOvwb77YsnO","st_dist_02":"j9rraRwuXxZaGEaYx85L8A39","st_dist_03":"yHw6ARJ9QWoIttPrXS8hcYZA","st_dist_04":"iHvWA7pn3Il5Dn4jAohexzLX","st_dist_05":"DQbBNWB9ZKadrlte31zpmUcj","st_dist_06":"9xR2xnk5uAVXIf9DjzwmSrVK","st_dist_07":"tBEMmLNvmMQF4JFeGYCUILBL","st_dist_08":"tGPjueAGRJ3ZlMWOCqvSCIFP","st_dist_09":"SX1WqdRvbEVuyIfmMSNGaAsR","st_dist_10":"TRGfGVXKzgyAJo7TQXgiAY3O","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"in6V8FMNtXH6AODp8nzn8qubOT68HrvLxWEGsCvgkGTM1ohQQd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":20,"st_w_id":1,"st_quantity":64,"st_dist_01":"bYzYSrp41rOZ01gAKITGzeLd","st_dist_02":"0YjidMW2csvnLq2dWeEVWJGK","st_dist_03":"wp0My6ftkDb1G4bviNMlrRR0","st_dist_04":"uXVtUKXac5hRLxMwvWPXZ0wT","st_dist_05":"QcGOchBS0cyo2Qziibiblsy9","st_dist_06":"9SVMxgmz1Dz87KoePbU93qAo","st_dist_07":"MXvU8ssMUYK77pvSdUrXBSX7","st_dist_08":"ZUld3OGbpDzt1WOEYjevkrYS","st_dist_09":"Tt2GgJphHfeUVIKkEjhb2Avs","st_dist_10":"5BZbuYWAZ803MvYiRM7NUvpj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DrXzg1soV9XU9QXgTu8tDxXJHERHzsGInV7MWVyC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":21,"st_w_id":1,"st_quantity":74,"st_dist_01":"r0Tr5Uy7m7CB0G2TXWrFeuRT","st_dist_02":"ImB9bKeWoUJBKWYM0Ftlmkx9","st_dist_03":"xZ9ihhP1iFQNd5HpFmuhziUk","st_dist_04":"ZnsVQ6W4sFro4tqk1YoKY2nC","st_dist_05":"fhppPSOzdRtM2AI01Bx6Ch96","st_dist_06":"mHDQ04MVZFZFeLCcLhaiGAuh","st_dist_07":"rdGwj3Z8CWcvTzL0Ky3590Vd","st_dist_08":"qUi0fU8wI6Jf8UIOWBF8goyo","st_dist_09":"uuTobwpd9LxJVzYUhQnN39El","st_dist_10":"LXNWy1HmlH5MWtoqHulCrtYD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"koF4E4db0bPdO6VcT5WNL12qw17dJuW8eole5oCIPdTGf52"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":22,"st_w_id":1,"st_quantity":60,"st_dist_01":"K5w2px0NNJstz1lYlRIU5zcK","st_dist_02":"K3Wzkf9i9kyINYdfKrT7rP9C","st_dist_03":"YtDYs3qah6vbHcRWh2DlAXsg","st_dist_04":"zHWUWZIAIw7wuT028QkOmj2k","st_dist_05":"PQvhuEzCkdH97beENCPUs4DA","st_dist_06":"2DnpPgzKYpcxo4RQ6T9p0ReY","st_dist_07":"jPPvWOGFMdTGsaYhV49hD0sb","st_dist_08":"Yp6HDvuhuLNMfoCXqS7V0kV6","st_dist_09":"MzNPnnl6xGuzTBghhfOxCcev","st_dist_10":"Uf0vDWcnipIm7PosWcNL3Pn6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8aQED8hXbdo3SaozG5R3sN7xbZLjmqcYK8dRHhxo7HoqtYdUl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":23,"st_w_id":1,"st_quantity":74,"st_dist_01":"L8HhlVyxsXQqcXUdEeTYu8ik","st_dist_02":"Hig8IwDpOnQh8ZtGTo84KwKc","st_dist_03":"vn7DAvYKLoU1IVnC7gaUZLlM","st_dist_04":"tOW96Ye89w6RZpZAfXPUJBtz","st_dist_05":"h9CnQe3bj7C5GKC30HOaMjZ9","st_dist_06":"tihbbFjSeaivLgeorTfunQEW","st_dist_07":"8PHkXW776GUwdYwpT8PDx8QH","st_dist_08":"SAle165x8hqACNCPsPcfGRkA","st_dist_09":"aS40cf8Q1x7SJSZ6hw3hO6OZ","st_dist_10":"QaMmjqiEUUJigyVLGjvFHu51","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gz1gK1T7OSLjOOkfJnX9fBoc5uYoVh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":24,"st_w_id":1,"st_quantity":29,"st_dist_01":"5nfGtnpqYqnEZ5HXcVnCG95d","st_dist_02":"NOFRnBK3KpYypWbzPzp4hKof","st_dist_03":"ipdElZMNoFAs2c0pCfgW3trb","st_dist_04":"BFeTGybz1rWCfTd6K3yKagPf","st_dist_05":"WVpOo9auMxaK5b9rTRxGBQdc","st_dist_06":"i0eKiKz4KFWGaDHOJmnIBAUU","st_dist_07":"rBcRwonJdjKZCmAQJ0juRkkY","st_dist_08":"vrkYS3iDiaw2s0gj00VsMT6O","st_dist_09":"Rdu3TiuFybAAFq3MLeCNE4Hj","st_dist_10":"mfU1rlwyBdFU7VjqvgFU5Uqi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OG53ymUr3YcrrtdAkuD7hj4yYm270BLmZxT0XIgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":25,"st_w_id":1,"st_quantity":58,"st_dist_01":"jk4LbktreQT8VWWDKoL9b78J","st_dist_02":"1GG4zzHVLCHpWAVNBJ0CCra1","st_dist_03":"WbwGBhvk9sJ1Lc4RFMiQYP15","st_dist_04":"7HSFVHi5edr8VWUxgaIkHtTa","st_dist_05":"3Iv1AxpFhiX0dbCHgnYnv99Z","st_dist_06":"tVSkJWTSAapMBmgqND3tic3T","st_dist_07":"xKnmNeCeEiwbt51VoFd76ve0","st_dist_08":"lcwKDUPUuWrP2857ZpYemaUk","st_dist_09":"FghLMx8h4sz93WSOsegpj1o7","st_dist_10":"hsxRMusxImyP4NpKCar7ishb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tRMg6TeV9PGXuh0iJfjE1mY124VWOTXuMKZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":26,"st_w_id":1,"st_quantity":68,"st_dist_01":"ucK6Gl7FD6GAjGAWGyqliZz9","st_dist_02":"QtB5fuPEokcvsYgpcEK3UyLs","st_dist_03":"lwDCu11Hx0vxKp6uwVKMC3RU","st_dist_04":"SriZeShoE1zzLeSZz7AWKVXm","st_dist_05":"FCcWlv61PIOhmcm3zzF1sBDC","st_dist_06":"55F87cXTjxSnWY2S1p0Foy5k","st_dist_07":"FYS1Z3zw4wAPyKjRegTAdUwc","st_dist_08":"315DMYfLEH611cpP1BEBJfVR","st_dist_09":"c4XVm1iqbf66xZKPeiMFR8Wd","st_dist_10":"3zAVcfvh5STZ2NXeJHlMuVQW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"V0ohTJuE65eONeuOzPf7yQGWPVM77HlBsgSrt6dyWLLTaM3QTZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":27,"st_w_id":1,"st_quantity":23,"st_dist_01":"mTzlRhM5FwHZNalcyT119ozY","st_dist_02":"S7ix2GUrhtxCaZWN0jE7Ji1u","st_dist_03":"Susa2BM1VFs3l8DFyrC2Sg5s","st_dist_04":"DE2HUqF8D1wipOzCG6rzZQDb","st_dist_05":"c4KW8PIC08WW6hS2pj1I7W5l","st_dist_06":"49kKSpHGMK3UkOKxpAuxWoHZ","st_dist_07":"wgbT5oSIy0pMRRVY7zcrfxz0","st_dist_08":"nWBDpMVcKIkAkmysydOTGKmy","st_dist_09":"6NuqYLpvfv8OaxX869XqMGmp","st_dist_10":"0Az8J0ZmAOI9uqzGfguuOFna","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dGC9SF98kU499iT52Cu2hYd4VzRCnFFv7hBHUBj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":28,"st_w_id":1,"st_quantity":29,"st_dist_01":"BOwl5Dbt6L5uGhIyDf39Xqp7","st_dist_02":"AGwioo3TTqH8xPkoxnsX7Slu","st_dist_03":"lyKl0Kwg90WgctH2nKjTQUwW","st_dist_04":"Yj5Rx5vyUohtKAbFLwCEOIs4","st_dist_05":"mdGVTpvkNnroZxGPdPt69LFf","st_dist_06":"BSgA2rgKcFpRBBiCVy4nA5WC","st_dist_07":"OhT5meXKpoUmcMFHzDTMDALq","st_dist_08":"jHXId0gAbC1b72xOw6C6Bv4D","st_dist_09":"9DTxKiEHFIjSTptNJRTHCCWY","st_dist_10":"pZkk8LacCEo9VAYFLh0cF2H8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2JmKGDVr1L0zIqoriginalxtin1jVU1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":29,"st_w_id":1,"st_quantity":80,"st_dist_01":"Pmx4Woa2SaTdrG5kJgxPLUb2","st_dist_02":"BgwdGAUK3Of0tFZrxviOXPGg","st_dist_03":"7ey9o0OJpN7ahcB2KQ5mQsps","st_dist_04":"gAghLAqwnTk4aL8IJK2GUdzm","st_dist_05":"li3klm4esyFDG2Mg7dijYjzD","st_dist_06":"AGLExrjQwwZtcWiLcnM9cu2f","st_dist_07":"LsobBQ4g7RYqFj1wSBfR8Z5L","st_dist_08":"tNUDoZoyOS36o8qHI5QAYTm4","st_dist_09":"4IOXnpcsGRJ8v5jU4EOY9YpZ","st_dist_10":"v5gBLrkghYBPiBpiQ9HdQaJe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yinih8OyOpBuo7P7xLq6rspe1n"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":30,"st_w_id":1,"st_quantity":51,"st_dist_01":"MTZgJkv8Zi8mVCIAX32LGMUg","st_dist_02":"EBlmGpENUNhLzuouSLRcWWsW","st_dist_03":"oeww3c1nMRMhma9V2b32mBnh","st_dist_04":"shHUILxCv6DxQYnidzvdSq4H","st_dist_05":"xLqrJ7A7OYbknNg9MuUvEfJB","st_dist_06":"R3UdF28YJcPUS3YwqUvNFOwc","st_dist_07":"pPpDuMvqdnIoOvtMP0abWfmk","st_dist_08":"oNpO7EeCzBHyWqHfq5Apnptt","st_dist_09":"UPJwVW6lE9Mm9fV3sGGtOWIk","st_dist_10":"pkbSq8aLlNfM76ozwOQdYv5r","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rpblahlLeBHDK5Ko06dcYeTRWDhpos07h1xpTZQQvLigQgrdkA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":31,"st_w_id":1,"st_quantity":13,"st_dist_01":"W2kGwDtaF9E5ZzROdAAFM8Rm","st_dist_02":"1SFQiqGgqePANwnVyItpqw19","st_dist_03":"su4Lw1lGbYjYLNLI5o3zqqlM","st_dist_04":"MdXLptegi4X6AmSHvgZ2oniF","st_dist_05":"7MSSsNEMoYvyJQJHuVXgszpz","st_dist_06":"txYLQ9b5PczFBADuqhWWXAkM","st_dist_07":"99FJlFren3RotOTA7aSR35aU","st_dist_08":"HR3UjuUqp5hqtsK1nImvPkBW","st_dist_09":"aUR232cMTZK9mjk3Vdric90A","st_dist_10":"2vSw4WhNUR2io0Ic9vmsNUw2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HP2PnNwOy0oVqpeFGSr7Lugz49Hljg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":32,"st_w_id":1,"st_quantity":13,"st_dist_01":"rorxQbaBbS3aG3q4Cp3yXEit","st_dist_02":"s0bwFvAztfauV13jH4qWDwDo","st_dist_03":"A24oqojtiZu3O4mVIaLs4MSp","st_dist_04":"nhgyislLskN7bmILr9iM6vIF","st_dist_05":"LMs92H54S5pa6NP0C0dHsJxs","st_dist_06":"XVbkqtyAXmI7mRmUdqKmR2oo","st_dist_07":"OJFs3IqX8KokOVnydNQrRWNi","st_dist_08":"qfQBAw3nogXqd0wyyL8FXbjt","st_dist_09":"nrnJVklPaRCHCalddiOl2XO9","st_dist_10":"8NBp2JOEUWboVQtBnDKnmH4j","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SfbEkWCNAXbM9jDe5PHa4g3BzzMj8IFQTicJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":33,"st_w_id":1,"st_quantity":71,"st_dist_01":"RpSy03fIh4yU1QosxbcqhEKd","st_dist_02":"bR676A5XH94HK1fvjdVsUHTw","st_dist_03":"nUGx7d5CkM3qLZWHmXA3uKG2","st_dist_04":"UcCy4iL8t9dxaw1Eos3f440R","st_dist_05":"i4mViZbZb2mXWVDO2CzgddIc","st_dist_06":"sKvIcLddH2E0CCB8ICw2Ztsk","st_dist_07":"3dkKmBkblXFZzYGVuxHchkqG","st_dist_08":"tMZUCSZjAWxSGQOZ0mIrbGbd","st_dist_09":"Zj4Gn3dBE4u0euxmARK0jXPm","st_dist_10":"SGEzxoSaIreN84CIfAhTpjqZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3nZyvdLggaoThDuJuvC6hYFwQYEofsemyluBAi8xCDEISk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":34,"st_w_id":1,"st_quantity":80,"st_dist_01":"5hdQB9foCtny2EtytmJhmD6H","st_dist_02":"XgIaC6Lmul1eooHEDfdU1pfl","st_dist_03":"9TOYDNmnL59gpOw11nwunE2S","st_dist_04":"vZLDHyyteSHpk4jDfjSNEst9","st_dist_05":"FRwq5RJqKmkGyPQ7cwO2p9da","st_dist_06":"ZvMvSyWZzweoFMyNms8rCLLl","st_dist_07":"9fBFE6QWUTNSTFJvjyDeNC4w","st_dist_08":"iPBKwM41n4MfSkqxcafmnowj","st_dist_09":"tjtuvokRDkB2vTOXOy7WhC0T","st_dist_10":"d7A72Sg6KOidLPWm9xbtjNpJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zkgScPWsYU6hh2lXkJcYsruV4Mc7NHV6zNOTybi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":35,"st_w_id":1,"st_quantity":11,"st_dist_01":"DJGwzSp492hCJF9B67Pf5nIA","st_dist_02":"Ly7vPoTJivLrwkZr0zpdLzPI","st_dist_03":"p1OhwQ0Cavd0n324qbTZRaTQ","st_dist_04":"GeNkyCzz7CbVmXk1BSIe5qEI","st_dist_05":"HcXU1OenfzaN2A2VtuPW0pqc","st_dist_06":"3r5aLnrH91BzjRjlLv9nhmWD","st_dist_07":"lQgV2USkaTm0AWcj0ojPYJXL","st_dist_08":"EN41MzEwz2hvl35PfI24O2WF","st_dist_09":"CTHbdQXT4jhsTAMi7kUOzS1g","st_dist_10":"V0uhBOOwACCNHgOhh5oD6Ufq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CMof8he0rKUkbedkNzRKt0ftF8Jq327Fo4HjS4m8fcJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":36,"st_w_id":1,"st_quantity":12,"st_dist_01":"Fv2TZqxacnJ5IjmQp3a0uciB","st_dist_02":"ToT70Pq1CmiDJVsgacz21IiJ","st_dist_03":"n5K226UrdcnMVTVwyQIDnTTN","st_dist_04":"ApghbtEd8757Up4rCQNrbQA2","st_dist_05":"ihYBAVVVJIDbT2gjoZeCH6c0","st_dist_06":"1yBCp46wSXNrNUtpuTURNOou","st_dist_07":"YrvRdKQmCaWLGFNKcw2AXCNV","st_dist_08":"GxAKl3IS5X7XUzXc05esGTT5","st_dist_09":"kMSYxtXAZcgVUaVBvp42AwP1","st_dist_10":"v0BVtD1tG5OoALxGBtnHn8xL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PlLdaEJ3MMz3IuaZHCdgnWaSG8mquE5Z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":37,"st_w_id":1,"st_quantity":83,"st_dist_01":"Rc5bi6kTrZxYvPetoMycFnlN","st_dist_02":"viCMprHkmmBnEMqzPhZGiUTY","st_dist_03":"oCRB2CBr9HHTseCZU5wnX5Ep","st_dist_04":"OdSBigPJMDDCpTZiYPzGa8U9","st_dist_05":"u9Gcy2pVdYU9pjRO7KOYVDAE","st_dist_06":"m4mAjZvPbTJo2w0YbQZ36wz3","st_dist_07":"Zu4rvuYbOgy9ynIYQWpoDr2c","st_dist_08":"gvfZPDBbyleAZZ9rrtOJV8Is","st_dist_09":"IJdvwho5jFX13vDM6yAibITK","st_dist_10":"KcxUHqVzsFBIBeRy2QaMJdsw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5P6aLfAuBqN7kPbEPF6V482uUBJfpy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":38,"st_w_id":1,"st_quantity":27,"st_dist_01":"TRq8vgL7y697a1JDWJVcGJWW","st_dist_02":"gW83j9UhEsNmJrZxSCfdXtSf","st_dist_03":"SO78JHErry76kE8ibE5pSm8w","st_dist_04":"qsDbfN3uV2x4Z32NgyrcLqtp","st_dist_05":"lv8Ep86S3tmKTs8jFt6bIKSl","st_dist_06":"JzmfS997XZAQAxERHCVsy3Vt","st_dist_07":"BFXkD8mdwl8cqXxKvD3p1qRi","st_dist_08":"KJ91hRfkocRiNbjAHy3ZMaJs","st_dist_09":"yjwQI45senJoAHiMCLu7DcTB","st_dist_10":"gQ9aLPdR3JELDTxVdhmaML2x","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MD86Ba5vtV14oPWMoq7Bk6qZ0LRjwZ0LzViqcOMrz0eOQjC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":39,"st_w_id":1,"st_quantity":78,"st_dist_01":"3WvpkWFJabVHIWk6Fjk0rmex","st_dist_02":"Smjvmz9l9yVLG8enTCykOsmp","st_dist_03":"sXJULmAV2VyRCxAcNlzjQty8","st_dist_04":"F60vgDma6MiQ3cDuiHBhXqix","st_dist_05":"pQ5YR29N0W3B16bqBKlbMVQR","st_dist_06":"LglXps9IIdYDBErkElPxINpe","st_dist_07":"DHNav5TVZjWCpX0z99Db06An","st_dist_08":"oSfU5mG4oQKdOFatCfnrp22f","st_dist_09":"CYvIpMFLwR2BdWv5LIVvbkJW","st_dist_10":"7EYGGIMhZf5uJVi3CSyNB729","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"585LwzLV11FwSQxDn86TGca334HOVgXZyCXISqlA4gmWRSX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":40,"st_w_id":1,"st_quantity":55,"st_dist_01":"ANfsY3sxtiDrGLrJfNY2zlWJ","st_dist_02":"4MnOOmv2wmU0aDw58Qb7Rlm5","st_dist_03":"KTSZreN36jqF9xckCgqvNhvE","st_dist_04":"zhR2TXBSi9wpkgUbpusLSfmu","st_dist_05":"4agprOZt5mcm38bMF87oXiAd","st_dist_06":"cTWLtyR0M16tBtUVTlWsa2yd","st_dist_07":"k2QwhoORzLlTuf66DgQzO3Tf","st_dist_08":"dqaEtl5NwzvMEq2cdSlSpxjx","st_dist_09":"6vWGMEpT8HhSJG362ERptLr4","st_dist_10":"MySsHQRiBZHm5lQQQMqLlIf8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HRU0Nzb56FKY8OM9Kdv1oT1CGcQCmiNvLLNb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":41,"st_w_id":1,"st_quantity":18,"st_dist_01":"vO6qnY0kkOc9B6sz5sH4FNW3","st_dist_02":"8IJwRlvjrTXDva5zaXXV3vjI","st_dist_03":"r3iSTt8ItUF66b2yPXGFX1Ma","st_dist_04":"vdiAEFX4KlBJv1628MSRoQRm","st_dist_05":"ej4heVaiJTSX7zxrLCQNl65y","st_dist_06":"jWXJHOkd7wpipZXfpuMgsEE6","st_dist_07":"OxLWcOqcP3GouV8UfCJdIJYt","st_dist_08":"FBWhuaykJAaDcyte6ZBnoAaI","st_dist_09":"1eJY3v8FVzEe0PYb6EIjCWJu","st_dist_10":"MctrBQrmcg74u4dA6pWLw5n0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cVYm3nWsv6BYhph5bGUeG1QfgD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":52,"st_w_id":1,"st_quantity":35,"st_dist_01":"ZB7kKjBbk0ZLt8g6JOqURiiH","st_dist_02":"OqvL5gfKUa7DcH9sPkeywG73","st_dist_03":"CMZ699sArlvM4rI1mn0eYMHt","st_dist_04":"UfMydS0aqyiiDtoyWhaKSbE1","st_dist_05":"AxIviImQwS7iS6jADcg8W4l8","st_dist_06":"cTYxKp7oYkmRRvFTImFl4lsC","st_dist_07":"qMUemcbZe7jlrBNyjtljRVdT","st_dist_08":"9i7QOsdRyYu45tNq3eyRgftH","st_dist_09":"fOssO9DZxSYOEcQhW2AMZUkC","st_dist_10":"dmIX0NWtgt8F3FI4WJDsv6Pq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2kPz0sVd3yTel8zNpMm65I0S3Df5oAgO3jDd5SvSzTSVy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":53,"st_w_id":1,"st_quantity":47,"st_dist_01":"19iiAd92TPPGn4bIuEZIoRut","st_dist_02":"CNrCf6eQkGln4I2k9ca2LGfW","st_dist_03":"CpxUCGi2YRfr8kfVea5jeO05","st_dist_04":"HaUXvNhM0ignALzQkGcQ66Oc","st_dist_05":"bRqN59atNahmfKsLwTnomQ5i","st_dist_06":"OHcrKwnqaqDH4FjKlsLtFDN3","st_dist_07":"6lZ02zBNmlJDNWEkci0rmoqn","st_dist_08":"p0dTWLIABi3MWi3VYj5IWM6s","st_dist_09":"aT0E48KVyk2fewirWV1izrIl","st_dist_10":"hNfTX94gsP6P0Jz1vy7y5hNI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zMUlDVKZjLoF8ffC2CkYWbTfwKQ3CzHyjzW2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":54,"st_w_id":1,"st_quantity":26,"st_dist_01":"g7pbRREKR78eYn1rz2PT9u1F","st_dist_02":"qro8zAa4MVT7DM4EuhQnE3Ki","st_dist_03":"8GIwzJShadp5HeSFHiXUeK4X","st_dist_04":"5yUFPJtRVYguihNByqd8TTt1","st_dist_05":"rb3XC4IVB9XdX0rKj91ndDaU","st_dist_06":"HWWQqlPl817ha2ORp9gndBSb","st_dist_07":"sF51jzW0WwGuseFUPgOJsiMc","st_dist_08":"zN0DfmmfETFKc6UDkcJg4nYj","st_dist_09":"m04acKGhpJNqe5oI6pQL8Yj7","st_dist_10":"AQduETDy6YHhE4qjoKVJPv3i","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IpZSZcw56tFkiWSFeIUvkPUPWCJKitB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":55,"st_w_id":1,"st_quantity":27,"st_dist_01":"MCJ0XnJFE8O7NFFelkTQMDwd","st_dist_02":"DRu0iH6v8U0zC3JwFL1fgvte","st_dist_03":"oisG9q6WIIr18PfVk9WXVgQN","st_dist_04":"PfYW6Jut3lmPirhDk7gXyjcz","st_dist_05":"YQofUWzojmGD0dL75sw4u1TE","st_dist_06":"jqHrKCJH86u6aquebyeEsCCj","st_dist_07":"n7HfCeaaP3c8pd9DUA9IhetE","st_dist_08":"19eM2SdS3qXPNNNSe1RKlYmL","st_dist_09":"LwISTdEC8Igx8ckTA6AQWkw7","st_dist_10":"LRRloaGWYvPvRKhUUkBUzvT5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yOFOs95ZyHATEwxDCcUlNR5KZ8OEV6L4yQGTjiV9L6M3kdx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":56,"st_w_id":1,"st_quantity":12,"st_dist_01":"zJXNOHHNxwBpnzUtHZjsOORy","st_dist_02":"6NACNmKutn7veqA3eCCyrS57","st_dist_03":"Ptl5ejcNXocohOQanRABDxDP","st_dist_04":"KFDGQIx4Lh3sJOsfptu7q4B3","st_dist_05":"y6yUuUrFMf7wJMZLuI6MPe8C","st_dist_06":"77e5SLy6Y1lxSfCXtnlzNcV8","st_dist_07":"LAhrJW8bFBvlp2HfuLsheu1f","st_dist_08":"uQ2SR92ArNwMm5yU9DKSLZDU","st_dist_09":"ZXuSrOPKPDo0wF66VnqgEg2f","st_dist_10":"iX6ubKS4S9q36h0Hr3slxyWM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Fnzd22CDFpFjO9X5EF02TVsrCs1DKkhcUlMrohbTD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":57,"st_w_id":1,"st_quantity":32,"st_dist_01":"tGjgrR1P485WTOEaFfJDszeb","st_dist_02":"Fr4cGwPueHUQHfeYnRZAmyjY","st_dist_03":"GrjSwVhpPZicA8G1TyxGlsdb","st_dist_04":"mZp3E0iq4BOlXjUCrDu4Yzuh","st_dist_05":"wwbJcnNXYXzCJ3jHyzRiOQ5p","st_dist_06":"zIUeKPChsFkMoUIVXOqFCkox","st_dist_07":"c9Whx9eJRVIu5ocVXJjpEfwZ","st_dist_08":"u9wE4j1CywKTaPUGiUx90MdY","st_dist_09":"soqSJqkzbc500xEgEh7sEUlJ","st_dist_10":"ebvpdeBPs85vbOBjjEaMIxdt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hkZnhq8J6YXJpZddKvdGcJXWx61ttwRi730qcko0C2MnxGJoP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":58,"st_w_id":1,"st_quantity":43,"st_dist_01":"tyccIFaGURKw5wTLXRdCOQrv","st_dist_02":"gEcSZMaBl6zCJ2iXtTnbSjE1","st_dist_03":"lEyw6YE2WjzdlGgQN36Ek1JO","st_dist_04":"S5DbSoYTtANftqdghOEjY0Ii","st_dist_05":"B61LMN24oNwWCnMUF65smg9G","st_dist_06":"nKyfBnHJ6KEnwFnKQmmuOjQ1","st_dist_07":"SkMBTgWBUaSs3igSdmEn02zL","st_dist_08":"3Ip05uqbEJUhMrNbKFdWnKsa","st_dist_09":"B5t9b5idZYsiJosa3VMnO5Ou","st_dist_10":"WaddeS5skuRApmfVMlhMjBaT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sqafo86XGHcIHePc5jBsWbeFWQ3Zo6iAezmWIukgg7zu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":59,"st_w_id":1,"st_quantity":46,"st_dist_01":"EHy33lXj16abTrEFflVTwY4Y","st_dist_02":"QpxXIJmiHaXhjNU5f67YkmRA","st_dist_03":"um4N20klZWtItgyD7TPjy4e2","st_dist_04":"lMcEkShvpfLzvDdk4k76bsvm","st_dist_05":"M9AZAtPO2zb30p5RBXhXjNKf","st_dist_06":"mhFjCRcs6ZmojRGplFe7P4DF","st_dist_07":"eRTec6YmQoLZmcXXKjXlyzHE","st_dist_08":"SdslqwGazAa0oBwGYsKiloOq","st_dist_09":"mvwuGAhl404NUXPMV9aqAR70","st_dist_10":"CcKjmv2gGdbtqlsYUAyVQir0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KtCwE4jev81xetC2tuOJUb4Mb2ToxWWWsQe18ZrRuxx8a0dsU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":60,"st_w_id":1,"st_quantity":94,"st_dist_01":"NbzjTzyzFrkoEZBDzoaBC6Ih","st_dist_02":"u7Hwc2kZpAR22rxGbPdoxtAD","st_dist_03":"BG2Yd71R7WAH5fc6utCfZWUw","st_dist_04":"UN7SWD8DTfTmWnvbF1cuRra1","st_dist_05":"oV7tTJWt0tlRdlQHLYNYlFNp","st_dist_06":"h9aOkmeyIdvrp3VBl7acPLoH","st_dist_07":"LnXz1wz5GrhG5cv1H65wnDf9","st_dist_08":"Wv0D6NphwfaJJ2Jkz7MNKz4w","st_dist_09":"W0pJz34P5oHxSVeyp7svgMO6","st_dist_10":"wZa54WoFhl2EywizYK7RWonJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"a3pMAo6VCY2PC1uGucblOoiwAczJrOdpqroAauZ8rHP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":61,"st_w_id":1,"st_quantity":37,"st_dist_01":"ObWAxLVe4Zjc0mRLtqHxm7g5","st_dist_02":"uY8FeYlHihMKzR3WDnvjH98S","st_dist_03":"cMSSMB25J3kyQ0hUZKjqGrPO","st_dist_04":"rA6ecR0tYvsQegxukBqVfObE","st_dist_05":"xcerMkh1uecpJMoaLjCR7rnA","st_dist_06":"6yAujgHq5ssW9Ko12wgfvpIX","st_dist_07":"pShut8XEVpl1hygk6HHL95YW","st_dist_08":"OqbI6wXgDi5o7PNwaU7CifBU","st_dist_09":"iBG033Lmivnn4fhQzqIjqsD8","st_dist_10":"HzWUTGfdipT3HrWl7XlkglNB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"r506gbtFFfz8c1p1WgoIFTrNJkLVb6p6fo7ud7gKK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":62,"st_w_id":1,"st_quantity":31,"st_dist_01":"7PdtuEDIx90uIzOWl4yIhCrO","st_dist_02":"mEQVDBDGRWmpnIS36CoPXITS","st_dist_03":"qnkqeBncIJZppyunbORek4AR","st_dist_04":"QTBUpGHnxDkheWkJJI81TlzJ","st_dist_05":"7rncYcJLRltFbR3AxbDsjbcO","st_dist_06":"F4ZpXYQH1fJngai75wll2ZV6","st_dist_07":"ziTG6RrRGIUr8bgLrtJZBnzK","st_dist_08":"JcoMBv5qJ2VyCUk0cuo6glD5","st_dist_09":"sPCcFWrUFCl8ms0wmy321ztw","st_dist_10":"4mZKtquZoA186nXqzWPCKOy6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PuQndcx3rkAdhhEVyH0SHwdNWqQZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":63,"st_w_id":1,"st_quantity":96,"st_dist_01":"6sj1aTEb0uTsD75cILXC9Uun","st_dist_02":"p6E9gZq10tfxLe3xRAogl9ZY","st_dist_03":"LvyIEBDdcavY9NPCv2YEU7wi","st_dist_04":"u1NKctXEOhzGsfPwJBtPlcWS","st_dist_05":"w9u0jEMbTzTlT6eAEdIzuFBO","st_dist_06":"sOVgrY28xWoRtiO0nJPm8dp0","st_dist_07":"tz8K67OXOJlupXRapaZFZIMV","st_dist_08":"Ktp5Ha7KRuR4h0owOwai57gz","st_dist_09":"f5oHM6TDI0W55PdD8Qxu0qYL","st_dist_10":"qabeXzv4E8Dql9OFVrQ8fZLS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Y5KXNgTQmaFPDqWB9P61yqQcchPra"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":64,"st_w_id":1,"st_quantity":10,"st_dist_01":"B7g0bG0TBufpek09PCY1hl4c","st_dist_02":"hBaNAulZ7vlkUaGYRMifkYN4","st_dist_03":"nrHx5zkH669d1O1KGKsQnfqi","st_dist_04":"j3XPv43YrlwYUM0sqULKrfpV","st_dist_05":"8g5sCkdhkqiuDeM3jAYKlExL","st_dist_06":"IFaATj3KXvzNaNXVhw83Jmjp","st_dist_07":"MH3gckKUcjCuoxyUgrNnURhG","st_dist_08":"rpiocJF94ORQjPRnI0ofeXgE","st_dist_09":"2PFcwqCRERjboJO4MdYoDf5U","st_dist_10":"94HO0RBfAKfQGtRF5wLFDoLv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UWM5xm6Pe0UZkBbx6rCjOCjitOlO5S3LiXX9g1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":65,"st_w_id":1,"st_quantity":65,"st_dist_01":"ctfWTztg7n2YuPof0Pt1GBII","st_dist_02":"X8vkf7UNBVkRoWE5v6v8ngPj","st_dist_03":"025Vj97qIuREA11rV5zeYAh0","st_dist_04":"yHN82b43XcMIDjKLBhhdZAOn","st_dist_05":"ZVxLeGWQAosfTNvnfPhZnlO7","st_dist_06":"vloSk5daz2UavhUUnsLP0j7p","st_dist_07":"4gpxD2PxFo4ZWNBL9AqpgY5C","st_dist_08":"BAg0JUvn3Pe0zen4pBQgESxS","st_dist_09":"wx6ejszF3mAurZQqxjrOedKq","st_dist_10":"6z8zuZKJsMJw9gglgvt4lNcv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rV6hlQ1sncQ9nJYjLunQm5Z8JyNrkBiU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":66,"st_w_id":1,"st_quantity":56,"st_dist_01":"BAQmH2kXJrKnI581Mw0g67B3","st_dist_02":"CEDqAvJlpdt68i4xB8Mpg3CX","st_dist_03":"yogfPErYMNqJmex5841JvoJP","st_dist_04":"jiG9XMZS4QQzcHM11DzYsv9B","st_dist_05":"JIfcqssg9DfbjDv0dfL2D6kS","st_dist_06":"pV8XWJFEkm82fHzR8tdQeJDb","st_dist_07":"ZefNpF1Evqip7hJfBdUaiNwh","st_dist_08":"aqm64xLNF65aF6H8qViuyFLD","st_dist_09":"M50TpzYZd2R5l7ijupysefTz","st_dist_10":"F4BvqrlBFlNMe8D5ARmAKC4c","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1dE3oFePZmutWBcbonQNWAjAHQ7bX42Ed5mgylwA6aK1C9El"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":67,"st_w_id":1,"st_quantity":38,"st_dist_01":"xyqHGflNv8vr9YRvvlJRKE5v","st_dist_02":"lQy48G0rAjKt6Ja3gFJiHgUe","st_dist_03":"iVXzO2v8GAhjl9hpOOTApZXF","st_dist_04":"56IUL4027KgzLXQI4hR2c9Hd","st_dist_05":"WlU2O5vFJNGBVl05xe7eFwTS","st_dist_06":"83oiAjFuKYdZH79k5DD4v1t7","st_dist_07":"sxEh5QJMD8cuMGovhVn9g1zV","st_dist_08":"1IBlvNNq10kC40DXP6AdaZ1A","st_dist_09":"vFjGTyRRyzioyK06ieUQJIpW","st_dist_10":"qBvKhHAcofacunsca4DqIww5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"icBSrRVsXuTR7csLkpaiCCjDAl2wNHI5G"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":68,"st_w_id":1,"st_quantity":75,"st_dist_01":"aDL0c4jYkdO6S4DjzD02g9ip","st_dist_02":"ruNCFiXGDtpsmhbp8WzgojqN","st_dist_03":"1umgv1ljQdKF4erl61jWwFGZ","st_dist_04":"haM5SSwlPpoVFkTvwTc9ASUy","st_dist_05":"QaeCzEPw0HtzQRy9vOqv0t1N","st_dist_06":"P8IF5vvO5VNf2qocakjQDX1R","st_dist_07":"bwBgnMvIOvnjREreipLyBkcp","st_dist_08":"1B3QcYhxx1oAEa4a1kegD4Nu","st_dist_09":"jmYbcFz4dlRZLWN2NuicCexL","st_dist_10":"GINi9dfup5tcySS9oHTMVbLs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PNg9ti9R8AjuJcoGRP6gNj4VDdlOOwIJAOXLLzeohLgfmxm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":69,"st_w_id":1,"st_quantity":95,"st_dist_01":"ndeWuKh2TlpcPIEZusA56kt8","st_dist_02":"PnoJ4wDJDpfoxg0zT7wTkmKl","st_dist_03":"msY037lS3ad1LRuYYe5WGWZW","st_dist_04":"lvX8oAHHhiCNXbuChU5iDAwP","st_dist_05":"A3Cj7n1YpJLN5nEtRJDa2G0z","st_dist_06":"hUxIu6Uyiy3pcEM0l4a9Gf1x","st_dist_07":"PiDTq9Q7t8Idh0Ky5XmScA5t","st_dist_08":"MuVOq5PZbQzSldQaSUHuckP3","st_dist_09":"bFw1pSRzswo4VdrtXuKcwkTN","st_dist_10":"IHiP04kRkMrPNBiD1Ihl1e8b","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7TT6gqgDzzE4KW0Y87Ap2ZAFPDFYk5VkaV85KeyoXZj7EfF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":70,"st_w_id":1,"st_quantity":37,"st_dist_01":"daRchjl8WaDKmMlj1BFdkrX0","st_dist_02":"4ujQDycrE7J4W1oNiHElpx13","st_dist_03":"mwM8LRqRQlJiHiaJxdkFXSYd","st_dist_04":"vGmhz4rJrjmD7Q5sLKLtGBJN","st_dist_05":"TcUsNa2lrqPO3MbVmws37wY5","st_dist_06":"ASEKhTCefwD0rn78MQayDWV8","st_dist_07":"f1LObY9lNdhQAFrVEIq9P6q0","st_dist_08":"crRAjUQSGVvXX1hiMEeG5XUs","st_dist_09":"D3Pvsl7TPZlZDIyVmirhwaY2","st_dist_10":"Ugn8UPtfQe7RpGYCsbK4NlXI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MVGWqVcwCgSkqV8vX0c2JbOLPdvx0KRow"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":71,"st_w_id":1,"st_quantity":51,"st_dist_01":"yxoDSbVrQzVv0TPEl5gBxm34","st_dist_02":"ilp5SNtckpHMeeQkRmiEGTto","st_dist_03":"oo8YcTiZGUlV7srGJhjT28vL","st_dist_04":"jN07Upl4OF2a4ojwsVaB9HK8","st_dist_05":"BCpTWTaGZfJtytO4koMchdJE","st_dist_06":"bAU8MvMv66H2MpmKAs2Hsnuv","st_dist_07":"568aNAPgYGm8xgo2jheHZPub","st_dist_08":"b7GkJo7UHZaeVBLY27FsxMtq","st_dist_09":"CmAohcdvHspXiKDMBfJgaxma","st_dist_10":"4djYWVw9AYuCesqmXeNasCYU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ywbxGdSQv6BELGUO7dVU28Dk6ybZ2R104iWqUzJKLm4fZhgp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":72,"st_w_id":1,"st_quantity":61,"st_dist_01":"mtdNPRUzo6wjj1xS5XZ8NdaE","st_dist_02":"BQKydCj7Z1ItTcizP69zUttG","st_dist_03":"FcdupEzsyNoK4AUX6PLcg1Yb","st_dist_04":"3Dyd8eBcVSQoJU6ZIB68JT01","st_dist_05":"YOaTKGCyXAB187PNQpq40UOy","st_dist_06":"b5x1MLyb9TKPSyhvoPtsd2Gn","st_dist_07":"hyVdWMdxcKFWmcVV7AhBMI8B","st_dist_08":"HgstHg7p1A0ft7qVRo0YPByn","st_dist_09":"tPCap9VHmQqa6jYzN0OQfCII","st_dist_10":"fFbgGxoZNcLhXVCdeiDEwmMA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ENR3oDCnoCalYUplXNKRwv2a04Z8ATA09No"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":73,"st_w_id":1,"st_quantity":36,"st_dist_01":"t8PKtpBv73w6OpJ6tQFY7s5t","st_dist_02":"KJYaR1sCTGcaqYTYrOORR3Ey","st_dist_03":"wNL8JKuFtLlz6QnNqBTMtRfL","st_dist_04":"xhz516m78YwyIXerPxnSl3uA","st_dist_05":"7jqunQVK6HNzmud6kJ12OGnw","st_dist_06":"yBLyuweKcqIaVHDuq6EBHaRh","st_dist_07":"ckWRdlhcl0FyvOfC2BanEum8","st_dist_08":"gYsYqOeue4WwraSBGXlRWPbF","st_dist_09":"GxNEWEHY8jipNzcw2Kni3QJp","st_dist_10":"HXdy87KR7BPyM1oLYpqfH4Sq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"H292m2QtjpF6GhQwgZZREFYKJ7fdVs8eal5ur1CPug"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":74,"st_w_id":1,"st_quantity":38,"st_dist_01":"OQlnwCTfQy7TzBBtRTwlDXIq","st_dist_02":"fdFamy9LZ9JxKMXqMSdO8Y46","st_dist_03":"u29yrLUl8o7FivYTc8Y9JsFc","st_dist_04":"tUfb1H5kvrOTP7PpBJuwSEUs","st_dist_05":"EMgm1e1S4QjxFAlGcDMNdQck","st_dist_06":"RG91s5AW4GdoHo9oAwUio0Mh","st_dist_07":"obTcqxfqnH3XvPz60Q6WBw6r","st_dist_08":"QziPa3U5ADsRIClSlRpp28iR","st_dist_09":"vqztqcTsrzQr7uRj3DE9mF2D","st_dist_10":"Ygh99FGDrLFU0HDHMif3EyMv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AP9UNwi8hp3U2lSPmLpBgGkTwqoVoNxv71T3D08POJ0wRJuCI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":75,"st_w_id":1,"st_quantity":32,"st_dist_01":"z1pMe8ZqxHyrWhbTGwu9mSsx","st_dist_02":"epThJjZYCgcpOwnkgU9n5VsR","st_dist_03":"lS91RSlngpty9caxp2ho9cOF","st_dist_04":"sGRGqtkwe8J3NgCMtGmxfYz7","st_dist_05":"FiQjVmgtTaDkH1ssbO9BQqEc","st_dist_06":"7b1zuvPJ7fyZ6jgclDvRZd2H","st_dist_07":"1KgM8sfEMvnasBEBUwlR5Sic","st_dist_08":"NgGHZexGQZ79HnE0M1rcGLJZ","st_dist_09":"G65OAkl9iQsGNrgeASxpetIl","st_dist_10":"PpAbMTsMfNpcN4Q6eY3z3eG4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oSxHUVkOciajpxKuVW2lkjeEQcC469wcUdvC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":76,"st_w_id":1,"st_quantity":90,"st_dist_01":"7AelKVY0UfakhzpEfGLChgYd","st_dist_02":"fmEl3MGDboL6tPF14rD24TYi","st_dist_03":"tTdai1AAvLIgPsPOQQp2hecc","st_dist_04":"OmUYSZBbkRJegeT5aipreBYy","st_dist_05":"qJWdUbbrVnwYNCvI4BSDlhpm","st_dist_06":"tYDIM04TD8uwbbT55wPD7MMv","st_dist_07":"9i5f3fBkH7HBayd8qgVvMbNq","st_dist_08":"jQpZD4eYOY6L7JONnBRv7TEx","st_dist_09":"nO65aMzTAYfO0BEw4n0EWepB","st_dist_10":"5dxkRtNDncZEF46YVMYK1bSE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tEPTDmqTWNdEEwzKQu3oUj3gJw3bIL33xNv9Jm1avPEv3bx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":77,"st_w_id":1,"st_quantity":99,"st_dist_01":"HubXBsXeE8Hzpbopp4p41a1B","st_dist_02":"zjOwBRFyPDDCbi7bhdNpmyDu","st_dist_03":"68qINbMVaVRqNOw6h4VpOSCW","st_dist_04":"xNt9tXlaB31ZcuKMuAEJ64uR","st_dist_05":"VfqEeUduYhgABQ8HfqjaJclU","st_dist_06":"EFmjI4cucQC9M0Gf89VOloY6","st_dist_07":"8hdiMCyDbwPePxMJ9asBQJNm","st_dist_08":"vYV2R58ZwTljU6Zw1gbuGxKi","st_dist_09":"q5zxT1T4zGohmvaPcmNL09RW","st_dist_10":"9juFWMbgqAdxGSoc0DAmKwGy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QKngMFLgeosTA9rMsQIHMq4ypCk2dXd4u6vr6fZgnm3OH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":78,"st_w_id":1,"st_quantity":24,"st_dist_01":"lXMBwTdpwzMREdmdR4jTHGBr","st_dist_02":"0GzCq9YlfeeO4GTaVDFo3n93","st_dist_03":"dvP0ijszfCgt8Ak4qclSnlLo","st_dist_04":"dzp4qMDbnqBdADp1PdSS5fYl","st_dist_05":"5e2H6vf6T47ZRF9AJC4sCRkN","st_dist_06":"2LDyO5uONh9hPZ3Z576BN4L3","st_dist_07":"xS6kjG3gYazV9OfAAlspbzSj","st_dist_08":"jq5r1xUi6u7PAWssU062gscC","st_dist_09":"xz73UIFz4vkHbghnOQxMvsJE","st_dist_10":"7KnuJI9mB3vUhLl2YFm2dkIz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uBhICdcPwTNoRkoX6jiRmpwQhUF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":79,"st_w_id":1,"st_quantity":52,"st_dist_01":"3PBCAkupKhpx7oWJuMxpM2Ef","st_dist_02":"w8z2RoKmeI6OVveG8ywL91Zr","st_dist_03":"SvZLHUTYEmC8HVoAbpK5X5z9","st_dist_04":"rdaGMrP7bzkDzKcOM0V5mOSt","st_dist_05":"G0ocR1dBSHP3z3890zVWyhlj","st_dist_06":"pJmfbJTUX5n8LQfbBSbdxUtw","st_dist_07":"h5RkwZehlEKzkH68W1M3MdKa","st_dist_08":"NrSUlJ5x5hHTSgxujnhSo5Ul","st_dist_09":"s4TvHol14FIG1ro3ZTVEcw2N","st_dist_10":"u0Go4wVdv5nV07nuqdrQOr7x","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2nMmg2ZFcl4D1R1GB2pz5CP7t70NnNB1BPWaJWV0Yt6LeM1I6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":80,"st_w_id":1,"st_quantity":14,"st_dist_01":"1sxFIyKscaSuIQA5QjlS5yGQ","st_dist_02":"5ofmSno17lWQFLMqyWT7nLe8","st_dist_03":"24uFRRdpG4gCr9PTUK9vpNr8","st_dist_04":"cUs0Ie4bfoi6TJ0Rk67oW6vd","st_dist_05":"TWPXZKgrBR1f2baYXVFEhY8n","st_dist_06":"yLQ7tDzQyn0dHgvzH8SLpGoW","st_dist_07":"OFE5P2Qv2EatkPUJep3iminE","st_dist_08":"hqAgsc8p7iVansKsH8DMmQIp","st_dist_09":"uhnlMC4bcpVhtgACRbwYdpwZ","st_dist_10":"addQAzW6KnSTNACjFGBv1UbQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7S4Usj5bBfmUeuBN64FR7Xmn9xD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":81,"st_w_id":1,"st_quantity":69,"st_dist_01":"d8cIZc7oGbvKUN7k1fvbyLMN","st_dist_02":"fKWXnHIBPsWu23210cVDKuRn","st_dist_03":"7CQHkQoqipIuBpPvwxCeZ6fS","st_dist_04":"IhztoUEkWCxMGRSPN09Huh2G","st_dist_05":"PuatWluDDAN0F4xAOgdCeOwL","st_dist_06":"sfHqo2EkOiBQiHkXLdswvkmK","st_dist_07":"4ITrKvm1ny6zy6rlt57VWEiB","st_dist_08":"mMpnsaC28tgQ4hdpwASzaDcY","st_dist_09":"ftMaJoihzsA3u0vL25utRl79","st_dist_10":"r127rzL9XdiyA6H7Jki3P9yh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dk02fMmEWCZeHQzQIshTHyUDSGEa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":82,"st_w_id":1,"st_quantity":34,"st_dist_01":"jI9xlOU7IWZLVdMWOEYR3xRH","st_dist_02":"xSy27S6SWPo5cb4ZvOVoPmlh","st_dist_03":"QLuz3lN87SopPWuNjh56bPyM","st_dist_04":"l3HPVGXPgDfuUfI0cqcgAggg","st_dist_05":"yuIJCAhYEztFSIk1HyY7inbw","st_dist_06":"WLOTW5yVwnnBkMrM1fAkf009","st_dist_07":"EpBGbHKs3Og1Qlgpn4sCaEOf","st_dist_08":"HEp5RcS9UaN1G52aNH6ytJyK","st_dist_09":"CrFCLdKpEgc9PdfG718F3G85","st_dist_10":"xGfcvZnii9tTtjnuZibwGs4Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fKaCxqZDOBQRfuYpTj2x9hx7ArCYctVeM5rxLeEtjlK8fcgg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":83,"st_w_id":1,"st_quantity":39,"st_dist_01":"gJSzZ6kdT5VnKNXvAP4JEYZe","st_dist_02":"t1obEqJDn1HMloERteFxD4U4","st_dist_03":"MKwfdfWfo92PrwC1mBW030cQ","st_dist_04":"enQ0QdDQvQtVKeqVbkbqgy2y","st_dist_05":"tydblkPJigoKawqolqrLPXiI","st_dist_06":"oHuFpQ9P6aUBxFRVyZ8a3lML","st_dist_07":"HKj2qFTrRxzFyOrHZoj2IGkr","st_dist_08":"TzVXdxBkKTMkgxwUCjGeEbEv","st_dist_09":"5Gbdqw30Z6aQZtEFqI2ebjrz","st_dist_10":"9cB14EyQTn5MHpS9fTR0iTgD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ztxPZtOuF1ibDnbfoht4bPb2BaOKj1w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":84,"st_w_id":1,"st_quantity":82,"st_dist_01":"t0hJNnDyBXPBwcM26b8dnPDn","st_dist_02":"B19lcMcQj7hUKkWP6rKBH9Wu","st_dist_03":"AdfDbnP9vRZEaS8ZqrLzd22i","st_dist_04":"cnJtTdksGBfy0p6ihQuGZYAa","st_dist_05":"cE6xzbWNL3tb9xz3A96qmJ5S","st_dist_06":"YEtkJ8EN0L6aw3rpNv97Z1dA","st_dist_07":"92CgU2XRJ3Cdp0fxjAG0KYZy","st_dist_08":"kaZdy9iuf5LtPuUzokf34XYt","st_dist_09":"1njReHoTtPD69RhPm3f9jorN","st_dist_10":"tkAgV7wZgKfBNqBS5TPN4mUo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"c5AFs603QECIwjlLoVuqod5xON3ke20dMNuSembkOz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":85,"st_w_id":1,"st_quantity":12,"st_dist_01":"dtHCf9IAXdeTzZ41HVsh4Rdy","st_dist_02":"8Cry7HbCSkAdb3OFijNHGYf4","st_dist_03":"xWuSxfS3Gpx3DIDFOMNp8zMV","st_dist_04":"AFen4TjA7H4XmNK1zUeX9Qhr","st_dist_05":"go6sMC9nk56jWqp1cel9XNwZ","st_dist_06":"ZefyjC0N1RbgebIrf1kNXjVg","st_dist_07":"Kbd71OFuUA2UM98q1Ers2Geh","st_dist_08":"n8uYNuT2yvY6hKugiTkT0Q3k","st_dist_09":"l5wDgPScmD3xnciAPZrvhfai","st_dist_10":"8mTRYrPCQq1qRSHlwzM5QTMJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Aa9LFKhrCAPeDDuBea8SdRAPN2FLlQY0rubcJrBW8C00"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":86,"st_w_id":1,"st_quantity":76,"st_dist_01":"HknZDkVmjEkzs82HsroKFyi6","st_dist_02":"jusroyqn9SZbgecGUa2ShLm3","st_dist_03":"Z6OjFeWOE1pnick5On3DgEEv","st_dist_04":"KuQvYP3GUIHIF6EWS9xiFWzH","st_dist_05":"mQh7o5HKYFNr4iCK3tBPfbQq","st_dist_06":"xqVHKAqI25lyJbtB4MQamMnc","st_dist_07":"jy3iBToJ7VIjFe0sN3EKFRz1","st_dist_08":"hjreU2oOS6Tyt8Unuf7thmg4","st_dist_09":"Dv9rzQvWAtdO1G15XB9G4vUJ","st_dist_10":"xD8nQef5fLGKx4pEmBGdQMAe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g85yVIppOA9Zo5D6tzWAVIOUIm8o1glz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":87,"st_w_id":1,"st_quantity":28,"st_dist_01":"yPaKlSkQDCZsycwaoxxvuy6c","st_dist_02":"NH4BJQ0VyyVroMWovNvmsoxZ","st_dist_03":"VFT9pKe3V5aqlqzzBgEOOhlR","st_dist_04":"I71dieYZPCfpXLLu2XwydKYM","st_dist_05":"poCqadY9jZG1TSWasSg4zVUR","st_dist_06":"8LxgggqjnVvVMX65nv0A1yPp","st_dist_07":"7I7sOcjd2VxnqotDUCcltFDf","st_dist_08":"NGEly7iSzZScek9BGHsZEPBX","st_dist_09":"J9JKpFnIEHHkUPDLWnSVIXh3","st_dist_10":"Qns1XGJkIpZaCW4e38Kg7yT4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Zo7F4IfYnr8xYiYE0dcES4DqQ1N8q0YRoVxKOLfPOsfa9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":88,"st_w_id":1,"st_quantity":81,"st_dist_01":"rgP2WxAyQbw1NrTxM9dNWRyI","st_dist_02":"Hj0JmSCmXii8PfMcRKXQC8Hd","st_dist_03":"KDzAWM3rgdw0iipAif8ngiT2","st_dist_04":"S3VXYIihrI2wTDLR5slVrQl8","st_dist_05":"4IYsXHoNajDiksNkc0nTNDFl","st_dist_06":"PYn2gpA5AFuERANCmMzjaVit","st_dist_07":"6KVPJcQL3QFcN9m1koCGwjXK","st_dist_08":"Vtz20PiMx2RdmDUASXe1m5Jc","st_dist_09":"ogrLYzPLWVegnkqWdsH5fr5k","st_dist_10":"aAiKrkl4le7rxqGBLgKMyFd0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SckEM3ExO61EPuNoriginalOBLi5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":89,"st_w_id":1,"st_quantity":13,"st_dist_01":"vUK3JO2mRA0lGJzBC30tLb1R","st_dist_02":"gkDD8voJa2k7qs9nHOH1vzZb","st_dist_03":"TbIQl6skySmK3e4QxTjtN7Uy","st_dist_04":"NPaOgfeVg8MADz96SqdL6H8Y","st_dist_05":"nboElhiXzIqdPzNKf1dfmvxy","st_dist_06":"vlIFh3MUBC4cy3u2HHiDHpO3","st_dist_07":"ycCkk2Dovhbg6Bc5GqccngeY","st_dist_08":"lJrqgkptR8GfDJtVH5FFmsJo","st_dist_09":"47SoFJSoIRvNytDGNfMaSSrv","st_dist_10":"ZV4eF1HaxukmG7w9QHlaQPH4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gIMLzMEKqRKK1LZK2dQuiJqR2USz6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":90,"st_w_id":1,"st_quantity":30,"st_dist_01":"yKAgOaco9kFYk8tp7xOH7rl0","st_dist_02":"62VcHLSG2qP71x1Elsj66LXE","st_dist_03":"1IOFIU3y3BtRb2d17tbcUD0Q","st_dist_04":"7kct5ZORpyI8UedEShzbnPbX","st_dist_05":"jvOUyujZY2GRNxAnuB32Eabc","st_dist_06":"MfdwT2391K5NsUpiHTKrDDZa","st_dist_07":"NSMoctX6XuvLb1NHe4K2zr47","st_dist_08":"PtHRWxZLFLB4k6cLK5BMEGv9","st_dist_09":"dAds8XGWnK3VmvCuXUmcR4wr","st_dist_10":"FB9BXzB4y573y4TKRSIjkn2x","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"w1NzlSI28ToNzQEE12uhYSCyKy3iCU1mTWlB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":91,"st_w_id":1,"st_quantity":56,"st_dist_01":"2vWkbaHjl7Cfd8ajbs5aciqb","st_dist_02":"J8EaSZRJvINjkBtBL3fCpi3u","st_dist_03":"rcV8s53BrfVaOMom0YG08CQf","st_dist_04":"tZFwIvUo5xun3l655L59spl0","st_dist_05":"PTZfT8N82kVdonn11wYH9l6O","st_dist_06":"Wy3ZK4TncvyQWyHsWuMqnPLM","st_dist_07":"dVjZhnIvRoJow8aLLXFK2K5C","st_dist_08":"BbMzbgZfYn7gmiG21SkSKulq","st_dist_09":"q09C1d9V6oO29D7xn5glBmHr","st_dist_10":"q7hzP1sRJb2cWYyN6nT0P5nn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AO3FKoriginalF6c65mxztYLIh91E2PhhrKEnE8C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":92,"st_w_id":1,"st_quantity":62,"st_dist_01":"xDj216Py12czbljo4wDTTBLW","st_dist_02":"9cjDNpeto9IXPaqRf0IXHBWq","st_dist_03":"jDl93CI8viVgGz6qZCLuZ6lJ","st_dist_04":"mGoKqdU1ZyVGOmtl48MJJeC8","st_dist_05":"9nJIMcMIO5FSCNsg4VuPkNMe","st_dist_06":"jFkuywAnG2WhFszvNw0FWhTf","st_dist_07":"qXciSqotkFJAfcfpQIwsYuw2","st_dist_08":"wPQ6E4PMGksmtIhY3xWfvKpu","st_dist_09":"wA9NbidkPYthGENwgQvh60gd","st_dist_10":"icy7tGB4a0PI5xKfodzxMaYr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"u6wdQ5238L2gfTnp0ZmC2vEd8MM7nMDNw7y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":93,"st_w_id":1,"st_quantity":33,"st_dist_01":"tgQABuQf6yVPGoUYkO6vQgiU","st_dist_02":"QmSTHlgdMoObRWJS9Fs6Pivv","st_dist_03":"EaUugqqZJc0FFbmZpwcP2ofF","st_dist_04":"P4RZjeyyr5w9EcowA5hHDNPU","st_dist_05":"yfJDk7LvdUaMefCVMamx8PKF","st_dist_06":"zZEWgLLPeUbh3STPKPjpUBct","st_dist_07":"9PqAee6iCGshWGozSMyTE1Q6","st_dist_08":"A9Vu1s13t3CCKhvvTirtwwtl","st_dist_09":"mIV6QT9xlCVBCXvDuVRTINaI","st_dist_10":"g7TT4YjDadZHBjx2IUbFVReN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PIMq7eWRcwKzbE5jP3mHtTB8kYNnrqAs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":94,"st_w_id":1,"st_quantity":84,"st_dist_01":"HQjYn95xGis508MPzlAMsf0A","st_dist_02":"H9kmBDj7BBkDFbYeT0nP3VNc","st_dist_03":"LbJxiaDP7OJgeOyEEIJuO1iK","st_dist_04":"eDIZqXdQ16DZ8zhAc0uR88VT","st_dist_05":"4sXQJ0x6LfZmbAfRU1n6uWfH","st_dist_06":"Tl8Wvs2vwnkkWpMiE06qwVGg","st_dist_07":"2lQse4geO2JFxqA77xthwU0e","st_dist_08":"cjqQyjyrUXTm6tl9OFLZDPfL","st_dist_09":"uTyaTA0XSyORWMnHeiRYjvJj","st_dist_10":"BrPbN2KR0BdiFZLe3TP1jraJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ss3bvMb2FQ0cIhudCvC0extGGuTb06biU4l9uAuwrG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":95,"st_w_id":1,"st_quantity":19,"st_dist_01":"6U6YTRe6X77oIGPRV5JrJJ4g","st_dist_02":"4QHI7VCbXHFHY2NMTWKhZt1e","st_dist_03":"1PIdTEirYVzqoKgBWI4LVTWu","st_dist_04":"TRdB4ltODaMsVnFqB7P9d2IP","st_dist_05":"q4NryjrCFeME6jUKqVFPRGDl","st_dist_06":"7sprTy3Z2i9yeEnyJ02zTQnp","st_dist_07":"AqZu4VTBBnx4pYyfFBoTgz7W","st_dist_08":"5Y8eQKCgu5cZpKMnGJJy9eXM","st_dist_09":"XGFH48Bo13w27apYZYgbDgd6","st_dist_10":"HPZr69Y2XeUfZbs3rxRA90DB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aSQHOKJBAbhqkkaiXNNiw3eEa8xJ96rCk6NHWdcdmNNVLSVah"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":96,"st_w_id":1,"st_quantity":31,"st_dist_01":"atG1uwU86aveN9fTybCZdZ8R","st_dist_02":"lIfrdjQkSdq7Zdo2MvnYCM1H","st_dist_03":"oMYafmWGlI0VP6tCmiGw6GNx","st_dist_04":"cyfwDrXapufLIIWBcpqfZLuO","st_dist_05":"AlFoIFRYTnr0toDQlS4xtlEj","st_dist_06":"hBlJK0FAERn188ddFaN3wEZQ","st_dist_07":"w5X2K1gMhQO1AQnHbNXtdpNQ","st_dist_08":"wGN8mvbi4tfImLH8g0WW2GKk","st_dist_09":"Ltm8KWo4c9vMWOkJElHNl1nO","st_dist_10":"QZWzVRWCuwW3WNLDC4hUvKIN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MkRWQytwAUCt0C6dmXTv6Joa7JXBgJ6K4wXyR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":97,"st_w_id":1,"st_quantity":14,"st_dist_01":"xBVU4ov8gjPCjXcKiNjZrT8D","st_dist_02":"98Sa4ByLDVq1bja32rZ1UmJS","st_dist_03":"R3vqJvySP01JrMQ77DnFdaD8","st_dist_04":"JGMyfJSXqj3W60eI6isveX87","st_dist_05":"WwkDEGb0XtfnnpLcJOcb0i5v","st_dist_06":"TR67ozSuF6ybE4TlPfAAzjiC","st_dist_07":"nVIhH5EhskZk81SqWAFcr0Ei","st_dist_08":"UZ5nVsATBczluBmfrbpE9z64","st_dist_09":"UdoUtxENhMRBBq5faDZiM2qi","st_dist_10":"UMkob0e2KTXzkE79l0INS1H5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tCH2rphrkQW682Mz6JRNWxuXAtMaazf5bJvpY98"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":98,"st_w_id":1,"st_quantity":68,"st_dist_01":"nabFE1v5B7QX0oB3CnFpqMAo","st_dist_02":"iRSSX0zjjDN7jAAA3qmMlaOB","st_dist_03":"SPptRcaGoN9WThJky53TLx7N","st_dist_04":"vRLy8r5BPLQaDUq2oT3cyp8t","st_dist_05":"f6eV43AO5LUPGtmYIVgigYKf","st_dist_06":"uz8vAOhJm9jW9YsUjZn5jwAx","st_dist_07":"DLwbKFLWStK9otH4RLXzEWMK","st_dist_08":"XYFoLPFfwIa1zSyfbWe58sNl","st_dist_09":"S76aJ6nwTVIyMUr0Bq5t4SPD","st_dist_10":"2rKRvdg23nZIVnPAFxtU5DzB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1QAc4kNSjG2qgrMhnr1HFVGxrJAkRa9saa5e3yAmO6Vj2wlLfU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739234,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739234,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":99,"st_w_id":1,"st_quantity":55,"st_dist_01":"Y7YzOZfUtzG9MWv2FXWSg5BO","st_dist_02":"JiGBMCoBimPwuoM1Fh2EXIlf","st_dist_03":"vW4DuNkhncagBXamnoPOlnFL","st_dist_04":"5e4ZZS1LJP3d2hUObW5O2NwY","st_dist_05":"YfLAVP8htGNhmAo4iUItX0qI","st_dist_06":"v3MHfBiRpkHtbl1wfsh71URR","st_dist_07":"xYB2W7agfbmyazbmR0CgJGYz","st_dist_08":"wEOIhQhHiRrbaHualpApEKw5","st_dist_09":"zYcx3V8wp17jBA7XYaF8anTV","st_dist_10":"NIl3tKBhrSbhpK8l0bihcTSI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"suUEpI6SRLFaKuHGhFtfrLa3WKlKuQY0C8tp5bJojlY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":100,"st_w_id":1,"st_quantity":34,"st_dist_01":"YYd0HTVa0l6px1W0OXEPrtz1","st_dist_02":"rNJ6PAla2W08QiGDFC1tX0Q2","st_dist_03":"yxKqfmVQ6Ew2CLZzYdYXJFHj","st_dist_04":"WZImgeKz7pdf36fJBniCqXNV","st_dist_05":"8DOHMod8axHBm3dNJRG4c43F","st_dist_06":"41lhK9ukGaSXV8ofeAy2simM","st_dist_07":"vsJVbs2sUH96sxgHfliKwuId","st_dist_08":"dohiIfwa9w6UbUfMoCraMJVy","st_dist_09":"qzKBxxD6tVVBACakieV8xSV3","st_dist_10":"OLy0yePwRJfnmjflaf1qocgK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qEZgowzyMtX8bZZ4oj7Tyw8QZKKNk9emrREjDeV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":101,"st_w_id":1,"st_quantity":26,"st_dist_01":"ErLgcjJOiDDfN7WyDsh4bDFe","st_dist_02":"NiIj84t0kjRbvDG5tleUZS2w","st_dist_03":"hmFjJli3YjocWKH39rvxHxer","st_dist_04":"CUwjRwHiH4evR7u92AwvIcjK","st_dist_05":"ugQXOaE3GO3dtxTmhvhTzAzN","st_dist_06":"gqdbgdUqjHxT8qTMSF9oMTTO","st_dist_07":"hOiSNTC93b9F8NiMowFRynDy","st_dist_08":"XwEsl63R7PMgfHJifL6jRNXp","st_dist_09":"RqhQIXwqgfaMyHfhM4XRH4pq","st_dist_10":"7h7ZMBot3wrffTxRPnPLNoYx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ksoNaUcGYPsZFEUQ80uRlgnXzbxRw2ZnYJ63L9Qo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":102,"st_w_id":1,"st_quantity":24,"st_dist_01":"82rXpBpEfWoaGZwhmzFNFW9D","st_dist_02":"ChE07Veamag90EBuu02F0Xcu","st_dist_03":"CD3h4YGV0pxMv9DQBhKggZBw","st_dist_04":"6wPPAKEwY7pVZf12DtSrTZFS","st_dist_05":"Y2XawUvIuSb0n7HScapIBUGv","st_dist_06":"o9YqykQ66Pw00PFqmA5NMnRV","st_dist_07":"ottO1XxynZdXYOey4gCahmhd","st_dist_08":"00knpYBqTNXOXkmYHltesbz2","st_dist_09":"4LqMmTM6DjOyCC3agbHgL4od","st_dist_10":"4fHo2Fxy3bobmk95pzNpUUUa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WAFnbno3B4a71Hxff5OdcdtcABLytT5lf70e0VEftNj2y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":103,"st_w_id":1,"st_quantity":81,"st_dist_01":"QW26souA34We6ct54xbSTpB0","st_dist_02":"zliCwHyxNeejsbuju0NroHF8","st_dist_03":"MNqkGen5BWJhdfMgX5ORQbyQ","st_dist_04":"A51XSLxtSn3H8ukq1V8Oh2PY","st_dist_05":"3aji5gJKB9hYLMFqS4W2rs1v","st_dist_06":"BJeBMJbbJNMfLTcPYcpdeqVa","st_dist_07":"C0ZAUWlNtlnFwzGrThVG8gOo","st_dist_08":"dN8QwUGuMLhDfxWEzmaWeAqI","st_dist_09":"YNsLGEHP1SmbsTyz406iNUyD","st_dist_10":"tHsea7uP3mfW1B8Lw2zqCyq3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"T070lGdgLqNQLYuDjs4udsi8fZ4s7Ady2z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":104,"st_w_id":1,"st_quantity":81,"st_dist_01":"PI7yCtin0bM9p101IW3SWIKt","st_dist_02":"2lQZSuCZUwv5l7TgfSreykqk","st_dist_03":"n5eMped5gFREu14F7ldTPF2y","st_dist_04":"4DhzzuEbjDReKzYkHOG2WyP1","st_dist_05":"zefLMHRrj5vaMW1LesNTjlVW","st_dist_06":"9s3pKqfWH9Q3tHIdOrXRhh0L","st_dist_07":"B5zk77ENhieNL5lphHfge3HM","st_dist_08":"LPHMZfPDmyG1e3edasJSZtv9","st_dist_09":"i3RJYifq8SY5uabJuuStidDj","st_dist_10":"RLc6OgdCfse2oEcCACp2UG6s","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3tEWbDAX6RzRwwOGknDVJgCgAawMv8hyIcSBFCZWMT6Wj7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":105,"st_w_id":1,"st_quantity":45,"st_dist_01":"8IoZ3F7ESnNK6LMRbdeigexj","st_dist_02":"ULO8NyJEUViRgNxYt2yAvAei","st_dist_03":"bieTjMJKmdfI1q8sggRdDQUY","st_dist_04":"ZWcf0lgvisoq6STJ6zlIO6Gv","st_dist_05":"PTUBR48UrvN91aIE0HrZWni1","st_dist_06":"Zsz4LZJyTs9az06QrxiXe9Eu","st_dist_07":"ITZMd4RnD1JIZIcQQ8bjvCWU","st_dist_08":"vXdOysZKFNhBADKoh7Avja3c","st_dist_09":"tinTvLnW2T4W8f6dPeeYScYH","st_dist_10":"Lk5kg0HlRM1MLqrQBgGeJLp7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KBWNMCdiTsu8LbUOceoriginalkFPxjQi9wv4tnwhmgXfux3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":106,"st_w_id":1,"st_quantity":39,"st_dist_01":"ZznRA3Mgyxjyh4PskpUrmRvc","st_dist_02":"49YaIao38BJNyMIeEt4VNsWz","st_dist_03":"4nOYN10SYlLPxQZ8k2QrIq6b","st_dist_04":"q8P9SJy9asNrEQXAMTviTzHo","st_dist_05":"qZZtrdqClgO7q3n1Rqr1Z5qQ","st_dist_06":"AfLyQoSgUYAGDcrDIK4XZvH1","st_dist_07":"gZMDprVmvJF7rGBpRLgE5KuE","st_dist_08":"ElWymV5K2s3Q1ysLwjAFZsDB","st_dist_09":"g2QSVhpK1pMBnabRf10rVrl7","st_dist_10":"S3QnSfW1po1WiI7n3EdwnfAQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9KRvz413m79b3TzHIDCzsJOQzWsKUe8T"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":107,"st_w_id":1,"st_quantity":38,"st_dist_01":"6lgkVLR93ZDQoJqDmBvDdKYH","st_dist_02":"0T8AGujY1K22KpmknqlmXFMA","st_dist_03":"nAgbexflE2SP7k92SGjKcX9n","st_dist_04":"QhG4zYH1oHLrqweFxTwzJpfu","st_dist_05":"UvgzzL0mzcX2BPOgJqtxXRNs","st_dist_06":"pwlsEjsnezdkSFJdI32ZmiNk","st_dist_07":"aUbreSjwAp2CWLbzKYoxcipQ","st_dist_08":"CtbDwAmaC5davgqAoUJup2no","st_dist_09":"gcOR8BZyFFTBIiN0EuvUayKr","st_dist_10":"ONJzsr54kS2A1AikdsK2Fj3A","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Wx3Y68oPCDS0jhGUJhBtvsZjN7il9TlT36dLNfpmdg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":108,"st_w_id":1,"st_quantity":16,"st_dist_01":"V9zqLrw5c7Eom2rgHx7hCUUE","st_dist_02":"m0Z9GFoKjHss58kv9Xspokpd","st_dist_03":"SR2xb9uH1ISFU6qg34TOFALm","st_dist_04":"cu6ryY30Sy8Hvb2uNBcS3ruk","st_dist_05":"JsF6KmdIDOlKiAiZMlBO5lCw","st_dist_06":"5c6I7UyJIXrzqovvw0lMEpLr","st_dist_07":"fBBPi5zhe1oJP2r0aMfB3xgR","st_dist_08":"IdAV0N2BVR4O08yJwpTDpoQR","st_dist_09":"NrlvxoCf5MaWgSw6rFm5Vdbv","st_dist_10":"Tk1BLBLhSejfcdBiaH95DuBo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"W06I6v4NEvdc16o1GxY3L50vhKXexhfV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":109,"st_w_id":1,"st_quantity":13,"st_dist_01":"uQ0XQrgDPRrev8kP1M9zJv8W","st_dist_02":"UdmYumflNjcm5fWshZerGlcO","st_dist_03":"blUyMwI4PkQYJtU25YoHkZW0","st_dist_04":"wYPmcR9B38Yyb4Wl70UOVY6d","st_dist_05":"BIJjMJDfiZNaQpiF1oZKIuB6","st_dist_06":"v9T221xqJGjDEwYLfsK3yefZ","st_dist_07":"PJFTtu5dx5Ocay1uJUGIPiaf","st_dist_08":"ebgwW7WPbleX0JMCgpjdDSuX","st_dist_09":"2exfasdRnJL0lmW4tGiW7om6","st_dist_10":"EpLZDtmbUCRii1VYUQIZvTXW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oT1t5UQywssRgzQEUoErnVauIEA3Zg8yFMQenE1aHVrAW4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":110,"st_w_id":1,"st_quantity":77,"st_dist_01":"ZHiXlggYG6RtLmB8PlsWrG6w","st_dist_02":"CRuV090mJiRLKl0m8rhWTh4D","st_dist_03":"zWNqp24bDN8bOTO9WBXPJzTz","st_dist_04":"9lZaInwl7KDFFT9wvhKLn6WB","st_dist_05":"S0O1phDPixvz3V9uCZG456Np","st_dist_06":"7Ut7gRXn9E0rEUYz4lU7SWSY","st_dist_07":"mGnihHTtVp98QaWC2DrbMpGm","st_dist_08":"ClA7axI4OljjHRolBOA20MSP","st_dist_09":"eiE6ak5G0iMnNxsVFHWujPRq","st_dist_10":"bgITDuKjvMv8wBNv9ltpdUag","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dpPAdMO9u5vM77IkrtHMT2cBvr54n8esVtd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":111,"st_w_id":1,"st_quantity":19,"st_dist_01":"ca6hLCH58zbjKFxOgq58aKSQ","st_dist_02":"Ev6DmMtSPB5ItNzsZx7H0wxH","st_dist_03":"JH5J3OE9CxbI7x0jB4Y7A7PI","st_dist_04":"Kjd3gyNgFxYac3ZqCI3Z9ORz","st_dist_05":"FROwIn0kVBBBA017804KE9KO","st_dist_06":"xR8SALkQy6mxJqEyCo3v1YjL","st_dist_07":"sJlX3OLj0jz2I2xbwWMsp7it","st_dist_08":"fiTCTseGYK0ENFIySSrgA5Mu","st_dist_09":"er8AGfsp7IPMwhdHTmkZzx9X","st_dist_10":"yAyK1duIcTswBAZZNJC8hb8H","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6lVYX3YLTJtz4oqsb8IoriginalbWRlBVvOjMsTlUDOfs8R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":112,"st_w_id":1,"st_quantity":90,"st_dist_01":"Z04L4AGYeA0b5xtbF2lHtV8C","st_dist_02":"AUuJhKM9OyiPTekdcNYtreOz","st_dist_03":"j48Cqo4ZUhlFlLZQ0rq7KWR8","st_dist_04":"3DxTgphzmwDqkh7fiN7sK4Om","st_dist_05":"cEPVxFKf7P7zM23P4KtPuJ7c","st_dist_06":"StaHk2duKs7cEeKOYUm35A1k","st_dist_07":"9AkSz1mxJfHIn8BtwIYonAj4","st_dist_08":"SJgWqXZB0l6qeArlBAyOMDpH","st_dist_09":"NhR9EYeyoKKXwfy07UKRANel","st_dist_10":"ph9GBmiFg2yLIEJNp6DOeCpM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tN1iHPrA0apuvjhLfD04sxklKA9QWoNwmhow14jfdUGb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":113,"st_w_id":1,"st_quantity":69,"st_dist_01":"V3kwdQg5mQ4c5APzCM2o26i7","st_dist_02":"PSfyusCpnrkS57SA2gFlbxTQ","st_dist_03":"c5rwwAgoRBFtlMco6l9uvhZl","st_dist_04":"vUzomlZKplgtaZH37Es9OOuX","st_dist_05":"53LNPB3a61tdtrJTaVCr9vqE","st_dist_06":"o1WWowU8izOoEprnXvDxdtwf","st_dist_07":"GvX8S0qHL478MxfliSnY6Uib","st_dist_08":"OPvGEKiKvSO4WxH0u31ZiC2d","st_dist_09":"Gec03BkvWWp2BMV0ILcWpgcC","st_dist_10":"dtwvhp0lw5oX9prEtZcRbc0d","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3ic0r5N6h2rSl8DoriginalppS3chGW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":114,"st_w_id":1,"st_quantity":39,"st_dist_01":"FkKeQIFkGq0TCDPtQ6EtrOGU","st_dist_02":"RpJyk7NsHoQmILGvEplibW0h","st_dist_03":"Ex5uKg35epyatpow28JEPHwZ","st_dist_04":"4u2Xph1NPMsKn7AOafzjXufD","st_dist_05":"MNVTqgIpTCcBrSVSaLrGGh2H","st_dist_06":"hlANcRfN9HwDMXzctoLNTvwf","st_dist_07":"N8o4PNILBUg0CPd9s2PjJtbj","st_dist_08":"2cwO5agy1fNILhORfWRtjBLk","st_dist_09":"XqfPZy9P6XjYGUnURiMfUj4X","st_dist_10":"2VlE3vuQuO7lWBjX4pvvoWel","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uN7OdiSZR6PZAz617gEvfHv8HAOfxqSDNtn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":115,"st_w_id":1,"st_quantity":32,"st_dist_01":"GasJ2D6AvvQarCTY4gEIQJzS","st_dist_02":"tXP8GhR13NNsTOqWJVJoUdNN","st_dist_03":"tOMWr8zTvOs7beaetzWmIcLC","st_dist_04":"TkFG8aw9wSob34IZ0PMCq58p","st_dist_05":"pJvzQEdUwIsokUA0Drd8geZi","st_dist_06":"oy4XlaQVISLgGXgm0jeDSoHg","st_dist_07":"oZfhR0kPnr4MUfJRjLxhKQe5","st_dist_08":"aO0SUsevLQQQ6WbCIAr6yGg2","st_dist_09":"aAE58ZPb8vnMpgl10quRuWPs","st_dist_10":"Z1wZDyagGv72PHHmer8gZH5i","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"d23szjOPpBrYah7uEM6VGjLI6MbZ9dSCpBfEtLlZwGospc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":116,"st_w_id":1,"st_quantity":23,"st_dist_01":"Wk7RKpnNRd6oL5ujnqbBIbBf","st_dist_02":"soHmrYXdPv8E9z0B5umvqaZh","st_dist_03":"SMSJhwVasGANdpmakqJHDoV5","st_dist_04":"zdAT5PUHGKFszyp3OI7n5eZW","st_dist_05":"4TwNPQDhG6eQaJpuqj7mCUYA","st_dist_06":"m6bSdP5eIOWj8kcaf0CRcAM9","st_dist_07":"C7VlAK4wlx4aDEj68sMac0lL","st_dist_08":"60r5XabGDEiNijq316jB4uAu","st_dist_09":"gmBi0gfBAlFoeye6tgxRKw2T","st_dist_10":"yC7pxcGj62OlXyiWt8OjrBag","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"j4SNBXqX0RZaR8lKRnFqxaTcXNBGBWHA4W9aqtANKz3jLIk8jE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":117,"st_w_id":1,"st_quantity":95,"st_dist_01":"44nTdS0nLAegViepx8nABYtR","st_dist_02":"8TeYtywWhN4bglbNHpBNbpGk","st_dist_03":"claJzglTXzpdDHyuECjDkkI6","st_dist_04":"uMCBB5lLwJ3PfYnctLnFF6G0","st_dist_05":"D4MkcklNvaNFHsPGBLFfZXBE","st_dist_06":"g9VPWvTJkOlAkwMs879kTRTp","st_dist_07":"EXJkY6cdbcLJrlzDNi0D8Iy7","st_dist_08":"gJ74Dx0O6VgK7UCI8fRim4hO","st_dist_09":"yIDZpsRQo417EBK9rLS0PCQr","st_dist_10":"vWDN2N9Ir3xdfCnBtnhvAZpd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Vxmto0UbYjNsP6i0hEUygRbOpDHIrQpHEjoDz292ufJvwM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":118,"st_w_id":1,"st_quantity":24,"st_dist_01":"SVcSeX4tfQCwNrPpO88FODbF","st_dist_02":"4lCa6VeMDZYJ5NfOJGKDKaH4","st_dist_03":"hAvlzJt64HvyWfTm0xgchjCQ","st_dist_04":"5yDh2fxwkbF7Mul8q4Hfihuk","st_dist_05":"XkYLZX7owjvQrTkh8NqoIGSa","st_dist_06":"X2wFGOl0hoU0RRWhnC8FZoZC","st_dist_07":"r70rPZsmuUiBoQMpgdBNzQOT","st_dist_08":"3PX5NV4aauTH7mURzvuxBp4Z","st_dist_09":"JJI658dAEqiQKpWRRmj3HXYm","st_dist_10":"4CXcQWcWfKELhrzZqU97Ql8J","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"l55lA5YPRwr5in3iJs7nk5mxdL0SbWUsPuuNy3xFBcfS8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":119,"st_w_id":1,"st_quantity":55,"st_dist_01":"0d1ufetB6HQt6CTiNn6ddKeB","st_dist_02":"y3DktpUmcelhapYBfYYFKjbl","st_dist_03":"LKIfbeu3cd8GyY0xyy53o6dF","st_dist_04":"j76IlRem9vh8BCfcNiCcHPsI","st_dist_05":"OJKv06n3mXs5psc8MdxMyYV6","st_dist_06":"ZGf3DjgsR265pYbP0OYgpTDi","st_dist_07":"idacwFq4wAXLy6KawH9EGnbI","st_dist_08":"huv0Gs5bfEnFkWfr2JAgu52T","st_dist_09":"95QC5Wdz9xLn1ZSugPWkz8gU","st_dist_10":"rvodYpTvDNzouBxNubrd4PVT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ce4akbUUnWvSM2neoY7dqvHDsBEGqAAiJLI9T"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":120,"st_w_id":1,"st_quantity":94,"st_dist_01":"kwDdQco5LlhtPPJeMK9CkA20","st_dist_02":"PpzBcxDB0GniWucR5hPoDg7j","st_dist_03":"UqK9daOb6jG28B8EAzQPS8db","st_dist_04":"ib8Qq3Z1frX5nKREArYgox9x","st_dist_05":"WtTzHA9mgKrkF4eT6jDkejmV","st_dist_06":"ZIuQaOK0jOalNpc21scoMTAm","st_dist_07":"6go8MFuHFxnaqtVfWwDN1pVb","st_dist_08":"y8GpxPbZC3XtCVCEPtfqC8UQ","st_dist_09":"yKYPuZu9QSqs5LRfj83oXGe7","st_dist_10":"p3GPlApVvWoP2nnhxM8uuNVt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NuSmLfVAhYJqLq7YRNoriginalfqwx8ITtVRETZ5FU9NhKKH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":121,"st_w_id":1,"st_quantity":89,"st_dist_01":"ierbYONnH3lR1esuhW3T2vix","st_dist_02":"R3uKMO2D6lpKGsnYOeUKICVN","st_dist_03":"C6tYdNfzrE6zVS7Lf66sMqsr","st_dist_04":"B8ZMYWNbBtOGeOTVEJmuBI9e","st_dist_05":"kZkUGPUffxgXWPlv1CSIoV6o","st_dist_06":"y6Hct2v8RZaKLFjUjl3YKMfW","st_dist_07":"nT5UCQDCJpjomjZdgEGAzz9f","st_dist_08":"eIHWSOw7ilDmeuAIoaGiRg5g","st_dist_09":"X9EBRYBoEq4AjqWMOLgqimhY","st_dist_10":"EATLK7xQxphc9PeWp5z7bGkL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Umc06Qqx43NIJKOfJPKV74IEzQb0n5cjmYI9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":122,"st_w_id":1,"st_quantity":35,"st_dist_01":"Xy0vJcPLXxd3s7mGfVxvUR6N","st_dist_02":"e3GK5zD3yWIQzpQG8dsM7U1t","st_dist_03":"aoXXBI8Jhd5qm9X38thccqvq","st_dist_04":"QQcFETNtfNhQDLjWiiQFdwVB","st_dist_05":"7Y9NwMnb4YgzXnWhv0UvZOrz","st_dist_06":"47CMWt8DUzSG815gURqcTQ8d","st_dist_07":"onzRbNbaweKBfEGgt5gewcvs","st_dist_08":"c900bYk59VgyttvAyrB02Pka","st_dist_09":"IKRSzZeSy6rrnNTXTr8BNY1H","st_dist_10":"gnSlnw2Gxq3oAFQX72BICprs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"effSu5VFQbNiS3FVlLJPnB8mUN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":123,"st_w_id":1,"st_quantity":46,"st_dist_01":"YQRKxN2LvvPHHrqqbtluIj05","st_dist_02":"L3YPjkkmlFU5XO7lKJyEbqAZ","st_dist_03":"dIoqHULISlufYqVTrLwyRE8S","st_dist_04":"sIsT7gUlJFLLKxogBfNN8zu5","st_dist_05":"7piExaCCVmWNLZtYaI4qzUkN","st_dist_06":"z5pEddLYybPzqKZ6LpYsGKx6","st_dist_07":"2zJkPjohdZOCLOii9COjLLC8","st_dist_08":"LmaP2IcrmiubR5md3h0rqgbc","st_dist_09":"BNQGHv9Ihie2ecBAN41vGe8J","st_dist_10":"k9GfC7KRyp3enEmUo5ooOWu7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YOlOTTne48gxjBYijC5vmjT9mBYd0xyYsw5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":124,"st_w_id":1,"st_quantity":63,"st_dist_01":"by8s9cwzc9iKpL1fY5LDpFgY","st_dist_02":"LeWvqDzpL5kxBjTgUYRDgFeP","st_dist_03":"YOcQxb0nGgjVsTvJSkCRRgWO","st_dist_04":"0cG8dhNCyrgBQsusIeWTHfw4","st_dist_05":"PINfdUerqbB2LWtGsq8hWtL4","st_dist_06":"c2bbNaKDihe6Jv2p2jZDEB5b","st_dist_07":"5Gl5EsG0amFKy5oIDnjDWrNr","st_dist_08":"bxqEQJ3Vhgl9gjdPSd9ZI6t0","st_dist_09":"quqC96uD01lgotDAKxPYcAO2","st_dist_10":"KuhygMdrCVfdgltvGaA02xni","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZZWkUNAQASDUARhCt4foWdR7MICfIdjT8BPOcskRlyF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":125,"st_w_id":1,"st_quantity":61,"st_dist_01":"HQYtZWzlOzp9dp7pifGHtAF2","st_dist_02":"BcFFUh178ECBFrcWOJ9fmiWG","st_dist_03":"FZe8ibFsR6hIIKX45yFjaTV0","st_dist_04":"ar6H2wFr4tku0TdowTcft682","st_dist_05":"sRZPEZkWbWaSVoNP0vcys9qw","st_dist_06":"zyqkuwMldt6euccSC2PC7ZPD","st_dist_07":"0nzU7ldM9YOPVaZ7Sgn9oFSP","st_dist_08":"ZROLIDmkAslSxX1mrkMGnPk8","st_dist_09":"3xLI8EFikxHgFjl2Xr4iYvfa","st_dist_10":"hZ9uAHHiW4zufK6UutYrOtiK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wHzc0m99WO55u4HAwH3MMG2YFmwRJK9EG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":126,"st_w_id":1,"st_quantity":19,"st_dist_01":"tW8l302tbkZyA8Z1TFGs8mEZ","st_dist_02":"smoz0wGszf54oR9nAeWTHFo2","st_dist_03":"xzpVmnl2PuhIt5p5oCfGXOUS","st_dist_04":"SAwCuEmoLplf4p5AF8WWi0el","st_dist_05":"yQHp6gIbRHDaebMKIUkLNshp","st_dist_06":"emOdnwQWDnlmgEDvSyFGcVTf","st_dist_07":"ugQbHReRjsmMCqyrqiINiZE6","st_dist_08":"UuHxhf7YOiqTPwC7m2XeYXDB","st_dist_09":"5QznI0h2ZqHqgWEUz6RVtRWf","st_dist_10":"LBGHMSkN2mrH4sHfRM3sDXd2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AIKC7Gcr6g0uqXn02TKbdttnL2X7iWXj0xgLrRkWyc64e1n3X8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":127,"st_w_id":1,"st_quantity":91,"st_dist_01":"IzjhMyvpr3CzSkVnzCI8jVPk","st_dist_02":"lTel3MnqBmYqzNIdjk133Q4Y","st_dist_03":"IwkYBEaHo68JdIpqXkyU54VP","st_dist_04":"GAhNDUv6ACVsatUvSFpoUYPH","st_dist_05":"BIuyy1ii6LwuZEhfFHQ7YTTu","st_dist_06":"fljfEJupdOJpS7E6PtYMtzlL","st_dist_07":"dXPpABbn8GBYb9aIH4ie2nXI","st_dist_08":"xFSAt1yJ2a9IpY2IfdnhYo6W","st_dist_09":"EvEGMvaxIQkXcBSjZ8kpCxvr","st_dist_10":"x63uCxiORK1UdDPvWqD5B7Nb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xRuBhTEzxpnwtK3xZzXk8IMvNA6cd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":128,"st_w_id":1,"st_quantity":86,"st_dist_01":"qkgSFhwflPglw7WwFLs37fIn","st_dist_02":"UIJbZM6LGgBWssuVK3vFLXle","st_dist_03":"hUgyTJB89TlJJboT9z80SDwy","st_dist_04":"v81q0LKI1mYBQF3cFlj1aisn","st_dist_05":"fpMqtuhFGrvroldRlFENqfOo","st_dist_06":"le0Sd4HZOXFljOuISlGs4J9E","st_dist_07":"pvmPH2cuu9BrEg2DhYujTRsK","st_dist_08":"9TyPAvaQ3gIL5jmxwNHyqRox","st_dist_09":"LLY4hlilXt73zrIGLBz1n12Q","st_dist_10":"m12sluUvZ3W2Bn8m6PaXgTS2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"re6tY1BUSmzGaRLqBgkQUNVmyal4PgAhGBBNFhd6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":129,"st_w_id":1,"st_quantity":50,"st_dist_01":"LRuyOdXwtWr2XENMhWJD97Zl","st_dist_02":"tmXRdnZgKNPQvq5KGdwGkZTC","st_dist_03":"CYvYRiLEtFLO4kDBU9ndIsd9","st_dist_04":"gEMRpmbj834kgTAeyAZEm5r9","st_dist_05":"K2vwW2hncZWxOcQHmJIxCKhm","st_dist_06":"VQxa0OyZkOQHQnzWSpmPwk2O","st_dist_07":"hHKvftArKmnLGHOjrDlTZL0v","st_dist_08":"htYU1asMsb0gJK7FHIqU8mle","st_dist_09":"QTZwQKWUedsVmTKSIOz4zBb6","st_dist_10":"sZddp6kBzZD87ad060bU96KL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lfXERccTuuBGmUjDOQvVBFoIT9TlQBLbc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":130,"st_w_id":1,"st_quantity":74,"st_dist_01":"dW62dDskmgKHf3XgcGJtU1ff","st_dist_02":"mYmUyf90P6PWtJh10XxmCPt9","st_dist_03":"G2oFIEbVNzfSrW92kcrfPhlw","st_dist_04":"26HfzRHMENuLjrzNFX16i808","st_dist_05":"T8qyUEeZVYgVgA9hMsPau1jU","st_dist_06":"tMtAP338AwVx0ghyh7bwJ4fg","st_dist_07":"waJJpHvR2RMcsnG7EzBfGCaF","st_dist_08":"EB3lZHXJoIWT1yJgcRkTFEDb","st_dist_09":"05ltDYXxvRsYp6PFHTPWDHUG","st_dist_10":"XMfs0yZTBSoONngkQprEtUGm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"J8ZxdvBQA1AO74Y3nEZOfMFOWzM7dReYBtJ5GBlXqZaqnH9abq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":131,"st_w_id":1,"st_quantity":14,"st_dist_01":"fAOSe2WiXsCuxOWXWIhU9sQV","st_dist_02":"r8GCcxbq6vjYBkTUcss9Vl8R","st_dist_03":"UHALVw7xWFoa4vzxBcbL204y","st_dist_04":"VifeYKbfg3pbWQRouBO84MFP","st_dist_05":"pbYKdWlDygkKZfhCGE50fdtL","st_dist_06":"WW9wNYSGl5R22nIZ1Zfh2Xqh","st_dist_07":"tLum90rFYmxqvd8pA0PwLhro","st_dist_08":"kiB9L83KPPo3YrnW6EXweE1d","st_dist_09":"swef4SkYMY0LyiSmXeB63yDC","st_dist_10":"QDca3ZqEddJ5rDuEqO1FAz0j","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3dcajleVs88g9FQHFcM9lBaSaFo4dGHgJRT9S9nfdH2C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":132,"st_w_id":1,"st_quantity":45,"st_dist_01":"cnYg2U7UyEqrIKyqy5ihjVHe","st_dist_02":"u2RDroAcT6yGBse1v5cWMAGH","st_dist_03":"MOwb6YrDLsv3pAD7Kp14nzp4","st_dist_04":"5pxA8u6WzjRr78sZ3kB7DbET","st_dist_05":"H4m2QbOOlxu7OBCJGjSnu46Y","st_dist_06":"uPkbKXnF92AuKfBWjSXbaeEm","st_dist_07":"Bp6RTlLPXPZ3xFYgDXI1xUin","st_dist_08":"ZcaPPIu73wHcz4k2qRdL8kgF","st_dist_09":"vO5D28u0HAnYnodgQK90Rz5F","st_dist_10":"AWJHx1E35NjaIguWxRPbYunA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nXix4UuO26iU0SYetImGS1cGaPeAHU5G4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":133,"st_w_id":1,"st_quantity":100,"st_dist_01":"pocaE8bNNTrE9x4PDLEg3gaX","st_dist_02":"BOgYEBBaD6WEXMpEkOQ5o8L0","st_dist_03":"08hyFJ3jNiR3FDU19oXBDVXE","st_dist_04":"Jbd3PBUyekov4465VnqWOYtc","st_dist_05":"kPkS8CqkbtG6z8SrrFrKmXTN","st_dist_06":"8Hcbp5km5VIMTYIr69EOMCiv","st_dist_07":"p6bZwxv2reTlRZ7I7TZwxOPn","st_dist_08":"HLNF1JGIYbP2Yk6jgTdBzHdE","st_dist_09":"mTzYnNQkHlLSDbJdg3UhMbl6","st_dist_10":"48DT9YMX2gvrFjxpSgE8jJ1y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0Ot0SOnUf958qQv3HHrzMi2O52sBvGBB2lTe6ZQ7DX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":134,"st_w_id":1,"st_quantity":71,"st_dist_01":"ByVDC96WSnmWufCS8buiC2rl","st_dist_02":"MYslPrNOB8s7vzttcVFkSyFz","st_dist_03":"84ynaWSN9EJFQPI95nj8mXPL","st_dist_04":"lBBgGBPhkMkYz3v4g1SMIv1e","st_dist_05":"MO2ja0UXQY1QMue6Jjh7w9tk","st_dist_06":"wvR59l80MEC3bgdJyC4PBFEn","st_dist_07":"YmeLc3fDMzxGWlvI6akYYuxr","st_dist_08":"lLLS8RvUIpkMOp0NigBdrHPL","st_dist_09":"5gu4BxXmhG83JeA8iXuOUE3I","st_dist_10":"hbN7Rj8ATmtkD8EuZf8nAHSo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PLc757w8messdIeO4mB00Az6m17"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":135,"st_w_id":1,"st_quantity":56,"st_dist_01":"YFsWvs4Tz5Obq0siaAbqAgBA","st_dist_02":"xbvCdBQDrg1neeYNF2gzd7rZ","st_dist_03":"goTozzjTuFX4nSxNL2ujlEuQ","st_dist_04":"lVqykXqnR4MfvCMnGYBrJG43","st_dist_05":"9MuI0otHi0DHAHY3KFrco3tk","st_dist_06":"14G41Fffu2r1B2pYS42rc9Oz","st_dist_07":"jh5jTAAXAB9nBLP0r8xGUjBf","st_dist_08":"cVkJU8sRcs8nzjqbGE5FdtZk","st_dist_09":"YNap0g6Ns9DUwYglCTwS250R","st_dist_10":"wqTXODzL6y9h0QRzskML7Twt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1BRWUF3vKAbeeVhlGA0G4liQdOp0XocQpJofdf0xeEjQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":136,"st_w_id":1,"st_quantity":23,"st_dist_01":"XD7280Ac4QGg4U49CXkFkYZX","st_dist_02":"LMsk09V39kdLrgMx6a8PLSrN","st_dist_03":"nuICjUNR6wBOBnrfSIHCWTB3","st_dist_04":"xhSRggPbNwJqyGuGNIyyE94g","st_dist_05":"UmhHq9I3T4WO9UKBxPbmEWpF","st_dist_06":"KCLLJiiV166TlznUQDHJJ5h2","st_dist_07":"GkZqcfUcx2YLhpLoTDZNH7GA","st_dist_08":"Hz4osqOHnlNOJCxp6ZdblgBy","st_dist_09":"1B1sxDPMrhySCzotABnbKwoj","st_dist_10":"YuP5Tu3OLop3QX8hos5xZw40","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NpWRiNFObRLCEDgURIXjygzCIVfzGv4Fin"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":137,"st_w_id":1,"st_quantity":43,"st_dist_01":"iKMVvwh59Mxxv9ASZshk5UI6","st_dist_02":"hHQGBdS0ASctOi3txpA4lSqo","st_dist_03":"ZwlHy8YAisTBGDOvzAamyYNM","st_dist_04":"BVIdBxuxXyMaAcGqDmdyweU1","st_dist_05":"vX3k3rwAMvlJaUQyDKwxee2K","st_dist_06":"Gxp82CMxwwpX87BRfixSta6z","st_dist_07":"odU635MGdVTqQjMBjq9QiopT","st_dist_08":"VhjzlgaaEKTRFdMjRxAcwcXU","st_dist_09":"sF4gAehjrzswWbtXteK8fvxS","st_dist_10":"Vtf6W6PLoenkLaiL8TG8xwmG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"n4qzylFGqIH3WtVtwPwj8IYPIcI9H8DvVD9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":138,"st_w_id":1,"st_quantity":95,"st_dist_01":"Wr1h0bO60w2sR5gKUNAqJ2ve","st_dist_02":"I05D9xhrAIvz5VMcBTYFyC0a","st_dist_03":"9SFdfDQLkkbyZk5aoiF0kSIk","st_dist_04":"GguEVg3KC8hbsXVBzqkEhq7l","st_dist_05":"YJSJ2F0tsivrdsK7chBfkaWm","st_dist_06":"8pfE30zkixhajKF71FWXiTZH","st_dist_07":"DcgDTVMORDTK9TN4D9QGeViw","st_dist_08":"PPfBMCVQUIbx3JcR7MhhLzyh","st_dist_09":"XP97Ty2Nk8aEyVRFHDSJhQNK","st_dist_10":"LceXmcDb5ckfEBMWPO2jgTVA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KfzXUxqco89QU2K9YgimSCAFbjgKJB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":139,"st_w_id":1,"st_quantity":96,"st_dist_01":"sZ27MBT7XUnxWy3Xz2qflTTd","st_dist_02":"3TlVpuJMYiWCaPMqr2wclCfL","st_dist_03":"ipGTxUlXLCWATqvwTdEBArCe","st_dist_04":"9BbtYugrdkcT9nuQa5sBgHhr","st_dist_05":"EzeKQXmEl3mp3XdFCE7f3sa8","st_dist_06":"SHuRRmg1wf7EIh9xhGn91jDG","st_dist_07":"ywRPBRn52SuunujBEeDjiRq0","st_dist_08":"vCTWHjo9hCaVl2a3gVvIOoCp","st_dist_09":"7cegEUP1vGWuOjPhM0kjsP8e","st_dist_10":"0XCx2AmGdJW4M8IVOST2zCA9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4CtJGdjvFKHq4KUfKewWinCxcsqVwexHtvVa3nol4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":140,"st_w_id":1,"st_quantity":79,"st_dist_01":"AhJ2Me118ilRnpaLY4Vp8P7Y","st_dist_02":"f2fpwl7rR3lhYAw3m7Y5l0nx","st_dist_03":"YGFgyqdHYAskJoYyH6z7S9EV","st_dist_04":"ZaHep3uw7kgSVp6aqnCspRsk","st_dist_05":"j5brZnO2YLqZsu5MHKzWfsqG","st_dist_06":"PYDA0LoVBccvYowILDbKLBgd","st_dist_07":"ytJX6L4OKNbDR0rMkglQ8i68","st_dist_08":"shgYA6twavSfxPYxba1BH4oo","st_dist_09":"rGILE0OVPjuSoe3mYSwJMyIl","st_dist_10":"KaEiB7LDU3eryXmO6oKV7lds","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3mmRvZDwmoTNCqz3pwLMY7kxfMq8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":141,"st_w_id":1,"st_quantity":68,"st_dist_01":"t3pVy87TydNayoNpIpqTVkc2","st_dist_02":"DJ4Ogxbhx33x50boQvef3Co6","st_dist_03":"4LNklJUC4AlYBPBUZoCPp7yt","st_dist_04":"VEtUUg9rWva4eJmqsG8gklgZ","st_dist_05":"Vab6lt0WqPAGfeHCVRY8YsjJ","st_dist_06":"Ep53HQGWGJqOrdqN4NUJxss6","st_dist_07":"9bzEt4B8J3RRxFWUCePEITT3","st_dist_08":"g4hazXnegbILci9CmFktj7B1","st_dist_09":"bTOJfL6v4tiPM177QEcUGFpk","st_dist_10":"QLMwxk27HhGOtRIfVb3M11Jo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3dRAb4nlEkA9dKsdxn5x3Itm8yNRYVGj80irIJFA44"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":142,"st_w_id":1,"st_quantity":96,"st_dist_01":"I9jARo4NuGfWZWeaES8XpUY3","st_dist_02":"dG9lmQuEZCqVHvHVRi9Ca1xC","st_dist_03":"cDdoL3SM13L7NGJz9h5rWiZj","st_dist_04":"sop8QfdNF7SV1qQuFomZv50W","st_dist_05":"czMYL0xx1Yz6p4tufSJ8T3Jh","st_dist_06":"RKA2uu0l0bfInGCZjLxTK7ap","st_dist_07":"SHN9raEjEGMotj3DkwYtnTQ9","st_dist_08":"aHPZ7xgphHlAGee8osXGtRXi","st_dist_09":"IdzUX3GWb0UdLF3wYqpdHQpf","st_dist_10":"5TzR2yRUof8qz1SZOBfK3Y3D","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Y0original2fXJ3zLgAO0zXXarVl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":143,"st_w_id":1,"st_quantity":26,"st_dist_01":"oDooOkHAXhJvoAtQMWA01Ui1","st_dist_02":"m0kR5PzuPqDhys1DJHTU811G","st_dist_03":"zTvQG26i9vToSSsSHnAXXepy","st_dist_04":"XE8Vx9s5iwJlrvGrDyGsgsgn","st_dist_05":"wS9TuTtji9Eek3Zg9eVsTXSB","st_dist_06":"IjTwF4qxulDBYMfGH0tHc1FH","st_dist_07":"2vT70oKzfKevsOojaFjfR51n","st_dist_08":"RZCQl2PSjtF9hObs3NVz7TsR","st_dist_09":"HAFLQe2N4x3BiwdVkpKi54Rm","st_dist_10":"fCp6uTbUNx6fYy7YOxjcyv6x","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NImT2xDPihPWeqDv7FD90WulUJRoaj7rdcsqdKWjp1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":144,"st_w_id":1,"st_quantity":93,"st_dist_01":"jmQ3lU7pqVo6vIzsg717XPVF","st_dist_02":"clDNNrYv9e3OqlAZjoDSUnWw","st_dist_03":"1msE8jjT6keHtTwWsnjJeFOL","st_dist_04":"5SSxGeFTSVVljLWwU5fP78hw","st_dist_05":"GJ9qnB0VdE4UQawPhxC8W9sW","st_dist_06":"KPIlJMMcztu7JQrNUht52OC7","st_dist_07":"kSb4mjAp64ajUgH9diWQcz5j","st_dist_08":"lQBdnpxZFh6JX2uM2f5XTtHl","st_dist_09":"LOCFVGwb9NhvMonE0M9zRF5D","st_dist_10":"eXJWBhgzqehn7rSV5Qfpz2QL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LRP0iEQ9XJtbtM7L2WCV8IIuDKJicHUOHzfzSZdI3f6lNO93"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":145,"st_w_id":1,"st_quantity":89,"st_dist_01":"wi1DsDIOALA3vlLMGwznf3Yw","st_dist_02":"DLYx8fnTLEok591m9Znj0Ka1","st_dist_03":"K2gCyZJ0IibQ6ke2onyA0Jin","st_dist_04":"bFU2tBWlsgBjxccKMaAZ7J3W","st_dist_05":"7OBVAFzAiU75WLRzTR41VLGc","st_dist_06":"j6oz5sAfXcSyvkINQotyBhnO","st_dist_07":"Xm3PG13KzoVnkRft953kbA04","st_dist_08":"VBRnKwkQGeY1z5d5jtBWxCZV","st_dist_09":"7pNnEiBpqe5avPTIXki5Lsqv","st_dist_10":"DagHTGyPEr186iLdZHbte6PT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ikx71i5WbS0o6XAkTmWa9LKc4fz9aRaoW1CYQnSPoSxeY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":146,"st_w_id":1,"st_quantity":18,"st_dist_01":"HAI3SXFab4QdnJbEGb1droY8","st_dist_02":"nh6a65XtBEM4eUARofxFG3Va","st_dist_03":"F8OujehTNN5ZXTniE5xo494J","st_dist_04":"r5OUcjRIry2RWDn8jni2viMG","st_dist_05":"5SoMvOY0wzyDxgB5tTh8Rwfw","st_dist_06":"oBQphp7NNGaFwTLGP7zp1jwn","st_dist_07":"bFI7z0lQsIm5PWkgvcu7MwN6","st_dist_08":"JnqctsGJAPKkSHKFbVjkoZWF","st_dist_09":"G5asP6QFjIr161EnbQVPthWa","st_dist_10":"yl0Ug9SZgw7VIC1Uv7e0SagE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VRfye9nBxjW8TmtBRifx1L1WigQRFWzXZsZ0x6Rp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":147,"st_w_id":1,"st_quantity":23,"st_dist_01":"qtrP1x7RX56aRMzliLksjAg4","st_dist_02":"9Ho2EdUsPn37oH1KGT7YWotT","st_dist_03":"Vv3fMroXlm8RZ3MaIcwXRAOg","st_dist_04":"YHK6jcwat8Oyw1TcL1eH5uUS","st_dist_05":"kwr43aJG2OdZnEBlC7zZliO9","st_dist_06":"n0UWXxSdaN3q3gNPKaoxl6GF","st_dist_07":"eRC68htoSlEBbs51BQJuqeO8","st_dist_08":"Uy3QNotbnDdZvfV7TyzvDpKG","st_dist_09":"ERA7x9YKQ6gh8Lye6ESJ2DiJ","st_dist_10":"zFl6JmN7XF481U3UBN2y85XZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"95vaIq13GcVrSR47lRspnqGIqggxS0Vkqc8ZxW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":148,"st_w_id":1,"st_quantity":90,"st_dist_01":"EfnFD1SPFEgrupCax417RAUm","st_dist_02":"IRdF0crH7qYdY8XodlHfkWX2","st_dist_03":"HTfjIilG7jfd79Y5ahvZ5D1h","st_dist_04":"kRjisjBdbOoZVxBJddrRJIuT","st_dist_05":"4LiJsI1bbsIwLCrPVVPUTskw","st_dist_06":"6zsjglVOMrUQUqRFU9ii7FRr","st_dist_07":"THRh0VogqTH5aJHP3FkHb2Mg","st_dist_08":"8RtmNRWuMHy6tLtzh33cJ7Bw","st_dist_09":"U1rnHRJU0Afnby3hk2Q4bSR8","st_dist_10":"Bol6v0b2acztjtJDU9bXpoKC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zoLgPaLhjI9CEP69AMnTd3Izixlx7UHyYy9RIVUTu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":149,"st_w_id":1,"st_quantity":20,"st_dist_01":"qPGjMN1nVsx46f6zaeWrsEDw","st_dist_02":"rkIqeR5sejJttVErRhkGoTBD","st_dist_03":"CazJHIMHHz8gMEOtU4lDjp9v","st_dist_04":"TpwNekoAGukPyFk7r6iui89y","st_dist_05":"S1AZrtYzoMTmnsH6NXmBnrTa","st_dist_06":"d9yXcQACBRY2qt4jFGl36Vrq","st_dist_07":"JuirPTcNX1ggA7Ty1JYxphcb","st_dist_08":"2lOWkOgBhAY5ojnA7VSzmNXi","st_dist_09":"RGOqmDTtEdg1TCkX1swXSnPA","st_dist_10":"tBZhAhkZ2fYFeGzKc4Za7vtw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"A0U8Pjx1C2sH4Z7C2kRu4J7OdP0lySAsjFw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":150,"st_w_id":1,"st_quantity":53,"st_dist_01":"0TzzPGB1dljbIW13FoKHScZQ","st_dist_02":"Nd6OB90cSowPIT4iWKZE1iwC","st_dist_03":"ypQJi2xsvM1JrkU5zFGAJmEh","st_dist_04":"2cKfOjyOhZTTalRGYcLSsWDk","st_dist_05":"e7gGYyNQiRHc48Txy2qzXpe3","st_dist_06":"AoyoUx4sDTXpSoD3QshY7SI0","st_dist_07":"IJ5DcYwezBLmlXBvfFf6CVvC","st_dist_08":"It0D1F60yB03q3fSEamQPBxv","st_dist_09":"uxk19Cc7cpiPAq2OrnXf0qUd","st_dist_10":"GEEFGNEaWnTIkidEL1zq7phU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xh1bdjrVhwiG8kMKoa0hqNB5Rsoh230jnEqxOY8pfXjf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":151,"st_w_id":1,"st_quantity":17,"st_dist_01":"oKztCCMnxR0KAcgazVglX1he","st_dist_02":"9cYMjJJri5Fge9xz2KI1ExmP","st_dist_03":"qdRAqltSo8rzohgJOF1zInfM","st_dist_04":"gLGLIiJ1h6c1cH6hoDbfDy7a","st_dist_05":"ibjxCq81AQPExRgzRmDQTIKm","st_dist_06":"DVwYTfIlQXPBwd8RMqxtpAv6","st_dist_07":"RxaioLk1LrFPoookQxrDUWX9","st_dist_08":"0XcIfFAwU7ikc5lQJoRC0HvL","st_dist_09":"7oL0wTnshes5cCy3hXOSB0OM","st_dist_10":"59oSFqfjfxsJxoZo2YPiHpGU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cRoPplI6qfQwrT8961wfEdgPMebaPzsxY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":152,"st_w_id":1,"st_quantity":20,"st_dist_01":"Jmc1XCGXZ9JBy8j6hUvS8fLK","st_dist_02":"BzAtwRqOoXJ23au5fuTjcO04","st_dist_03":"uPur1KMvYuHiFxj1uDOv3dCR","st_dist_04":"2qE66MXfPvTWiki5R3sTsqN1","st_dist_05":"CBqH29oqJ6Qs0oLlTis6XTBa","st_dist_06":"rGUN9AuM4BgwOdlChaf8DbTH","st_dist_07":"DjxmqV2yoH9UlfX2Y2NCZhPP","st_dist_08":"RDVkhQQ3iSkXvWHgrauv1FXZ","st_dist_09":"LeWyyj3htWyYfR5YGqqBbvz6","st_dist_10":"hvQqky3j6MnU3YGYGwLKznXO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OaHTbx5CyCTWWsdlRdId6WEANqlPCyU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":153,"st_w_id":1,"st_quantity":35,"st_dist_01":"etUF7dhEU6CYUM3n2JWu9cGA","st_dist_02":"Bc7LjOtGYRTRZT76pe7sCkbf","st_dist_03":"N08pZxQs2XUYUj1XN3IGG4tr","st_dist_04":"HYL4wcBZ4RmfrNT8NpapjjoZ","st_dist_05":"HPel6WIF3vlQaP04sbfR9QfJ","st_dist_06":"TGfOAShen3Aih3A2X8WqQRAv","st_dist_07":"tvItk2ZncLOIYVryOO2uWHoH","st_dist_08":"JdgcsCC36YRd7gphpLm5xsjr","st_dist_09":"9FzPoZkA1ceLEagPcYxaZNnw","st_dist_10":"DAeqtAEJB2wj45zzmN0rRfcH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ucHHqlGZ7q4e3rakKvaHiD32RsXphxBgMH9Gwmic"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":154,"st_w_id":1,"st_quantity":39,"st_dist_01":"cY3UZfZeg6iNKEyr1iiQj9Jh","st_dist_02":"fIYVKKQaZrufYBQql7LFPIVi","st_dist_03":"aJcv1OYzSqLoG0IQ0FvwODF6","st_dist_04":"fzwzWKL4VieNZta4E8n6eghA","st_dist_05":"TpBnJmMfUVGNmQLQ6myMfe35","st_dist_06":"9TjzJSkW6X5bHsvCpfh91jph","st_dist_07":"QtWgpKwe6N1jUNTVP2onvPfl","st_dist_08":"cslpTQrwPlIs34YvvsrKKQeH","st_dist_09":"Vx2QX61i4eFRgUvttup6zXAv","st_dist_10":"BodCPm0lGBZeyZlZS3OxNPMj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t6Df5oRIEbwDHazYZHfNxI545iU7xz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":155,"st_w_id":1,"st_quantity":54,"st_dist_01":"clHn3SYCDCLgYXLAYtQbkNar","st_dist_02":"3JXcXCW6BE9KaTr9a818eNuL","st_dist_03":"T9cCSMHfqNpl9Z1MvHhMVzTD","st_dist_04":"yVHMpgbAXxO5X1PfMtHUPr6l","st_dist_05":"lwx7FpCCiYqT7qp3hT2HcL8E","st_dist_06":"AIkSHl0sFs3plSYQowwhmTC9","st_dist_07":"4qfRXFIg4N0QNXLZ6V1egr6p","st_dist_08":"HTdWZLmXD2lEp6tNY4l4MBuW","st_dist_09":"s6cXB6w2O7gfoNEOkge31plp","st_dist_10":"R3TwTiUMIcbjY1RYmepTcRTA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HAKbl4OaiHkV3Y0SSpfDsrNUfv12xmvgXxhzKx5lBm14"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":156,"st_w_id":1,"st_quantity":74,"st_dist_01":"6fh51hXGbwoeUA6P92FC08lK","st_dist_02":"VWQMXAbZVCuStXL6B990EXac","st_dist_03":"aVtOZR6lxu5fN6czY5q9riFs","st_dist_04":"GopY2Gun4QaPkGnqsSRC7UBg","st_dist_05":"FIXszS1a6K3zwf2ePgrrfMjo","st_dist_06":"3DSJEhF0ZBkICEWBLVm2Fkqx","st_dist_07":"KT6ZCuvKqJJ8uskLDCpWSjg0","st_dist_08":"PdErr35NlvrlYO97qE91jCmW","st_dist_09":"cEeFzNI7SaxRcCZl99bA8aYi","st_dist_10":"RQoNSDbwSxyknSNsd4m0aO5y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CuC6h4qF7SNcLh0ezBc8bjsxADTMnznrS3rFPN3CxxH7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":157,"st_w_id":1,"st_quantity":95,"st_dist_01":"XB9jWGAKPXAqYJ3iq9t3cHQw","st_dist_02":"KMuJ0fmIidCaCLzR36pg0VA6","st_dist_03":"YpSDkRUlhUMMAJ0ygr4SnngE","st_dist_04":"YP2n37UOgXOBd1O2W6NGOY0b","st_dist_05":"GBAMo3mG0kyfQ2tGXVn28eTp","st_dist_06":"zKpahEg6AAiZcrjz9xrtfwJo","st_dist_07":"KUnKgH4iVCVWUXSg2uaqWW2R","st_dist_08":"WP63XgzAk8cdngtdODUHbqxA","st_dist_09":"Hp2jYF114waW8R4BY4qfwOJ9","st_dist_10":"tb7KjKy7dsyzyZEtDM63Xsky","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"js5nzz4Uh4Jxvvk6kX08RS4zUQKauAkNEggGg6jf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":158,"st_w_id":1,"st_quantity":90,"st_dist_01":"9yb5ZnWv68DwoOMIMp8deAPy","st_dist_02":"i7xQv11NFb4GZvzeJAmOwoKH","st_dist_03":"a84NGUgYRxDUO1emQekrDQB5","st_dist_04":"7HzK6zIvkueMJo3xHJ5GpuMM","st_dist_05":"nJP8M7plPJuXHCQnYynYhksL","st_dist_06":"yPkzGirfuwYbBFencUeL7pGf","st_dist_07":"3IT1o7mO1fNALWpR2MFEHBUa","st_dist_08":"jr7xds6lIrpEyXzt0AvyhUla","st_dist_09":"nt4eXXxdh8EDNpndQAL9Amo9","st_dist_10":"imMP1KKycA0Bb2syQmRboWDc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pBe5hjdB9GLcMWv3ZOJwlX3MZG7FruRC5odLSS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":159,"st_w_id":1,"st_quantity":66,"st_dist_01":"AnGruBXfODyz3ctvxseiHI3d","st_dist_02":"Ho3TEVLbrGKShP7M28fRIhtV","st_dist_03":"9BqDfbOj5S9cIqXMosVaYWCi","st_dist_04":"u4qychuSp3zpkbvWa25R5zro","st_dist_05":"GNNoBXbKeR5X1GnUgD2VNe3h","st_dist_06":"tweobmCLjs5kvjoiTjF0gFSq","st_dist_07":"foheq6vgtbDx0Ctqr97q7kKp","st_dist_08":"n1lf2b3uwygdDiAfox9DACLc","st_dist_09":"INL9h5KTUCohln3AA0JGMd1W","st_dist_10":"ONfJCgvQ95gbEdwXfle23luo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Rj8asc4H4SHZLsjrHw3oTifhp87UGCX4V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":160,"st_w_id":1,"st_quantity":93,"st_dist_01":"3BJHmMoKjBtfEc4bWDOO0j3s","st_dist_02":"CilyWSaoBRxnUPGaqdV3jrmI","st_dist_03":"jtcZ8DfRnaRE4GhJGFVoO2rh","st_dist_04":"M8FjMcZ5aRssV4fZL6w5XqqU","st_dist_05":"SmgRfJYgcEif9NHP5IkN32Fs","st_dist_06":"ZUvEbLatTIXSqwPiPosOIWQD","st_dist_07":"AopK5qjm0DvwF9quepBHtJwu","st_dist_08":"ve6x1nuJdQIULtOuUJO84EaY","st_dist_09":"fOYOVvYEZY17MhOfgX9xRJcs","st_dist_10":"EonbWogVdFgS7EkwFfRAYVmQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"r0jYbNkhkySAsJCoJjO2Q98LaslgwWVGOM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":161,"st_w_id":1,"st_quantity":32,"st_dist_01":"caoC2mmnqgODT2zwClnUwWi8","st_dist_02":"ykcXSx242tC2WFugBeeICKA4","st_dist_03":"KiA7W2qrudzaaC7xYmuWqCxr","st_dist_04":"u4x467gF9j8LxvxJNMgAQcp0","st_dist_05":"Pwgv1KyKGJZ4FUyqOvz6eQmW","st_dist_06":"oSgSXXhBU9bFOv3ztq25LWoa","st_dist_07":"rLEtgXHygb4uOs67h2GXPcSM","st_dist_08":"AcZtP1T8t1lf72djDUfvpJP8","st_dist_09":"N0MGiNEyP6QI6bUBZm9SauvQ","st_dist_10":"tnWFHTJm31UuHZRjyg8jkRFV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MznjVwQa1z8iOgvdZyyEQsKAjf1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":162,"st_w_id":1,"st_quantity":82,"st_dist_01":"35w529cjeHCUFfTvZejxn4O0","st_dist_02":"l0TMRE9jKXZfDOuDZpiLeErZ","st_dist_03":"MBasEEqPqs6GG9jl9ON8v3oz","st_dist_04":"2tzJ0WMKuI21amYFbZ32W6OA","st_dist_05":"ykrB866wfoAs2iBRacNjvOyg","st_dist_06":"8R55ynAJT7anPX5Vz4O63Ksr","st_dist_07":"oLRevQOdx5tWIKXc2XcvbZ0y","st_dist_08":"V3CvUJ796XzrBehNJ32zuP2w","st_dist_09":"CidSOgi4Pk4ARVuAZYApusqH","st_dist_10":"lz2Q8moMldnjAESaprTiWYCY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zFDmVegYF4q88Kkj8HPd341qKolRda"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":163,"st_w_id":1,"st_quantity":77,"st_dist_01":"FAVa6peDNssxpNBEI3P3X5nn","st_dist_02":"ZZNU91RHjhcIRfJESo5bbAxh","st_dist_03":"0c5FK2zx5t5mlxSPndhl1Nhl","st_dist_04":"GU9RHQFimzI0N69fQVyrHYXW","st_dist_05":"BOP5JmFnKia77UoNjT0RiBQH","st_dist_06":"dR2NqmP7VgrteJuKdYo2LQpY","st_dist_07":"pXaVfd0Pj2IKDaayCslXuNSi","st_dist_08":"r9Pevus5u3Om7CvrB9xu27NB","st_dist_09":"jlPFdlk252YHbapBtSMmyc5w","st_dist_10":"sHhTatlIa6yuzFtWqI5ovFjV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YK332eqL1y49OTMdej7VwI4Fpx7ZMtpj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":164,"st_w_id":1,"st_quantity":70,"st_dist_01":"xiDN5rKIjj0joKb91mAfWuW0","st_dist_02":"ro5fP40CLf8eB42vLJ4lMXEH","st_dist_03":"6318RBxlwE2F3HXWyTxVVBSI","st_dist_04":"C2x5UCidABTIPUDQCSqPNYp1","st_dist_05":"I0y3SsQVIaBKvsSUtTS7HnKD","st_dist_06":"a4FEQpE5Xdw73MeLjTYtmksZ","st_dist_07":"C5MpUFZucwl3bU6o9IZDexRq","st_dist_08":"WKB6l2Hs4FLhYVIcnXi2e1VP","st_dist_09":"x80wkQDBJ0KxRuvl704EKybI","st_dist_10":"mxTLgQ52YUkHfsv8tYqNUr8N","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TUmRby5pW79olJC39kdM848gogpesZENRIvY18Oox74"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":165,"st_w_id":1,"st_quantity":66,"st_dist_01":"1Irxmhx9ZO0VcXNCdpwIV3kn","st_dist_02":"ZLPHSnuE9hRv3Dvd3ikJzfgH","st_dist_03":"BeN6LyZOMbNwe8h1UxzcPmiw","st_dist_04":"wcsHjPgwlJRJANFErnVU1jMG","st_dist_05":"a1GwfeIkSBvdG6JXb2CmGctH","st_dist_06":"NkY4fr3yob6V0raL9hv2BJ0x","st_dist_07":"4zEiQ5irBqW2AIEVkhEHZa0Q","st_dist_08":"1D96yzo1qRvZtdHu6Muv06Kt","st_dist_09":"JvehLX9hJ4XrLhxTjJEph49h","st_dist_10":"1pbKBCGHzCrSXKMCRSGmpREc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ft84qiqnrglrQRZIYvbUcmvHHLl81MD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":166,"st_w_id":1,"st_quantity":42,"st_dist_01":"ygcXLwj3jYpuGMedSfdy3Yl0","st_dist_02":"RWUb6MOkYNHXuagQKYEQRGYy","st_dist_03":"JKCVWAtttcP8qt4z2JqqGun9","st_dist_04":"uvtIBbtp50KZAB0IuDCBC0pp","st_dist_05":"YRnPJJ6YPmT5rLP1aMaO4Faq","st_dist_06":"ax1eEIbptH8lBTqCmaAE6c7y","st_dist_07":"MzagQErXNigFUvzUscjLKJUf","st_dist_08":"ALW69fxYeetLLaUGO8j8niO2","st_dist_09":"XOrD4BYoCeykSiPELeHruIZj","st_dist_10":"XunlPJaVmYBeIqYcI5uGAOdH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RSmhoi73Q8gc2AUMScRRVkv65SE3py19MH9Cc65P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":167,"st_w_id":1,"st_quantity":27,"st_dist_01":"45eRJGdnVLe7ZCO0nNDcOQ6p","st_dist_02":"4YEQmiX91YnVOT4H5bS6DNVZ","st_dist_03":"5Hm58RYKYqguzBppzfGO1Hai","st_dist_04":"zvPLp29N8mW4WnFee7ReSqKp","st_dist_05":"56ma7W9cpDkkIdgq2cwdWuJJ","st_dist_06":"MjI4tbhZmelbegIDC6inzi9j","st_dist_07":"6LsB8UvkMXKHOsGFxSP4WSet","st_dist_08":"nInsgRqioOhlayuwpvxO4LOK","st_dist_09":"sfzYCEtq9KnHl2nyTczVDITC","st_dist_10":"EWpbpXI9Ri9KLP73cfWBx8k5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Q3LR0ewsm18JlA4lmT7u1sDHkyHP4CmBgh5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":168,"st_w_id":1,"st_quantity":89,"st_dist_01":"d9fLyYZeKiZpmi4QmQZksPzK","st_dist_02":"MjhSGcY0PwFOVpShNqYKA5kB","st_dist_03":"zBL1OyfHwFIQPDi9UebYpUTl","st_dist_04":"PCzfXTsfJRxWFQ3051IFLHE4","st_dist_05":"JsTLTsNFM22F8SDFkgUIDUb5","st_dist_06":"LHmzYJZIuPbIX2a83xLi9Nlo","st_dist_07":"8JSxSTQGg8hdmpHux2q5ZdG0","st_dist_08":"N4hb0IafPlD0n1fbP3xI26nF","st_dist_09":"4FWJECv2T541VGpidTYSUzXQ","st_dist_10":"l8o679V6pDPuiuPpK8Np9WXS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3fO1FbFmhaHEo7dpqid9K4wWiVGyg8BwPeUj0RMURwFGI31"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":169,"st_w_id":1,"st_quantity":54,"st_dist_01":"yG4obP2ewoYQ5cEq6UXBdDkJ","st_dist_02":"hTj2CmQ3ZY1kAdJWDn5KvBKN","st_dist_03":"1chxOVOPa0yZxIXFpuOAIXBs","st_dist_04":"Du12bZ6TrsnXSGA7JT4rRwFS","st_dist_05":"NrhCFckZa8zHHeBh1cJL9mCn","st_dist_06":"OBn7MvzrN9cUtbnkP1rz6KA6","st_dist_07":"ZX0sFgJkpIdpZC31bX0oJoTs","st_dist_08":"4T5ZaIdNwmUIlywS28Cq4S75","st_dist_09":"MowFkPiNZGJbpOKnRac7EkE0","st_dist_10":"Vk4u2kbGFFmPQyn6KzpjhUu8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"P2HQgsCrB7amn1CIheN7U6ab09nDoUIM4LXzuO6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":170,"st_w_id":1,"st_quantity":48,"st_dist_01":"cTObI98xdXhYjcUo1CmGghUP","st_dist_02":"KzgMoNFeXEMR5sxcOLxuPhIF","st_dist_03":"SHgXFw8RNbBW20g8xKidWxS0","st_dist_04":"KWKAAlYkL8oyrnwv37mDMjKH","st_dist_05":"hpJvNcaO2u1ksU7UUXatfKYK","st_dist_06":"ztspzlBf5HyEalUJK5uQ6Fni","st_dist_07":"Z7eMuYdlNStLcUnGKPBxBVZr","st_dist_08":"x4rdp4Fv4XWn1jIGFz43L6jj","st_dist_09":"1DhzVmrxUEWdDbtGZ5t9UQMm","st_dist_10":"Zhvg9yaUvXjB38Ys6WvptnBw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g6Z9pG8aMJIKqnomKoAfC54DCUaYvKsbi5oADpd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":171,"st_w_id":1,"st_quantity":43,"st_dist_01":"AlwQTnGLcAqByfGyJtYupdfY","st_dist_02":"b2uSXlKJY3xoVQke3dnKMwcC","st_dist_03":"VcnSP0km9XTj7BpeEY7pbIGr","st_dist_04":"H9sWMazb95eWYKMvNWXl2jiE","st_dist_05":"N6X5GPB8MAuonlakbWPzAVGh","st_dist_06":"To8pkdp4anVJKA7iuSx8ljgB","st_dist_07":"BduLvg1dfxmRlggDx77wjWMh","st_dist_08":"lkDUYAu2k3iCjXCKZOEBjE8S","st_dist_09":"oJesNIYG5ogpfiiAmRoR1w8v","st_dist_10":"iQvyveCoQouzx1ZLyvAAK9jp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qHxXBgfewXHit73u59UPdFUOjCtkpHFH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":172,"st_w_id":1,"st_quantity":60,"st_dist_01":"DSan5e4dkj6uZRZHa8jRwU43","st_dist_02":"5OO8Kq8PJTxHXQfsoVgzxiyG","st_dist_03":"7gMAX14qNGCJpZIMoudVFSSA","st_dist_04":"Iy0dQQnmnBWbj0MmDPCB99MW","st_dist_05":"VK6HqnHHKkTeYDrGPTW8ayYH","st_dist_06":"1TRR5wA421Vp6o6UFVSiLpR2","st_dist_07":"MqGwQgIGhLT3PeD34acdhEcK","st_dist_08":"a96EoTd2XhIn1j4C5OaQzwUB","st_dist_09":"MlYBk8N5nsfAd8dS7hru4QuS","st_dist_10":"W1ByO9EfnfUnsvKcb245oFCC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YlDTu5m5KXdZKsoXmtDeAZP89H2GPWPhJS7DlQABabT9eM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":173,"st_w_id":1,"st_quantity":26,"st_dist_01":"qq6gitGcXOj8MfKQaVJ5WFRd","st_dist_02":"v1aiPLn8UxFgGp3jnYFePeAG","st_dist_03":"TE5UiuSBo1vNS3QcF4XOfQ1s","st_dist_04":"Uk2oxahhycG5ITgoRLwwfaHh","st_dist_05":"IoYI9ZYgVKLlIczI55bt4et5","st_dist_06":"jdubBOxz3V8c8sSynwCEFaWT","st_dist_07":"MPlYiyYdtIhBsEKjiMImTE07","st_dist_08":"icqxgzuc71d3NxHATm2xHqIi","st_dist_09":"w0jEpkq3xr8YzCTJcwEnsDXR","st_dist_10":"nqMCU92u39yI0q0vb0H9KFj0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pXa7OqyvwmGLDUlBWGjrQehstpyi4LqIuxeyViG8kjH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":174,"st_w_id":1,"st_quantity":77,"st_dist_01":"F1VTNrpXKl0hzcoICDMXcWNn","st_dist_02":"nQfAR5SFhp2oAkedcD4Sgmgl","st_dist_03":"zy7igNuYAzFMFpla9Gll8nMY","st_dist_04":"0RqYzMbzZ3a2yFJ8WMP74yTX","st_dist_05":"Fh3WLZuDCtp8mquvZ5B6yPp7","st_dist_06":"F5v1u36rZFhJnda2ipwSx8NR","st_dist_07":"w9nRGc8IIMOGpcXJrnCirpWB","st_dist_08":"LtBb2NXOIFTfJjfGdP2vwdR0","st_dist_09":"APSC5GCiFCSkwpPkIzE53zJE","st_dist_10":"m6J0v2LtT9r8hhvCyrgH5lI0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AisXmOyXZNVT2mkR5DGpZCiY1ASXGm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":175,"st_w_id":1,"st_quantity":76,"st_dist_01":"7x5eGcEs9RDvxb1jB4Fw2XzE","st_dist_02":"X9ZanPDyqBCt6ScAv6CmgkOb","st_dist_03":"0AmXBkx18uYNXzFqWwZNuLU5","st_dist_04":"UQNYdb9Kzx9C1JSeBKoxLFTZ","st_dist_05":"vYQtKIwt6ZkDD83Wo9ddP1YO","st_dist_06":"KCOAoBN9qpoROB51nzjGq1Z7","st_dist_07":"b5wnASScOiiG9kuINJa2eW6T","st_dist_08":"OHIJCqWf4vyfGSIFIRizysO7","st_dist_09":"Mj7rGxoYWfSFfYMCl3Min7NE","st_dist_10":"G2vlUo2DTF75V4yKBmgEWomK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WcLtdEIi81l4Vb23AUiFuYlxcShzSlHNjmJLCQsMS3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":176,"st_w_id":1,"st_quantity":19,"st_dist_01":"pB5tvm08D0ImaDC0k1iWVw7x","st_dist_02":"4tfBQWQ0mG5K5ZZdHZ5Vsa5J","st_dist_03":"Ld4U9kGRcjP9L276iwgyF7U1","st_dist_04":"Hp2ELYHpzOmTVN23tmlzlPQO","st_dist_05":"PH3CAdWjBKV1vC0nKv5u6S0Y","st_dist_06":"DW2xzntJU9gTs5NRHzUJUedz","st_dist_07":"zSOePxfvWe83Sy22kzhMlk9E","st_dist_08":"gHpqKO7jDejMTpWtRGjqPhxe","st_dist_09":"MEyfMAeHi9QtVzByL9dAun5E","st_dist_10":"GTWuOFoQApiAtnjrUnFMdnCF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wDbx7eU9C2cHxsLkSwIJ5opPS07UvYQHAqvEjeTXq9HN2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":177,"st_w_id":1,"st_quantity":79,"st_dist_01":"JpbEhehozCv0QDG3em8TmNuD","st_dist_02":"inRsppaQfktBfygGANqRbtJB","st_dist_03":"K0HrWJ5ULrD4A1KFTZ2FqP5i","st_dist_04":"LezbtkzJRMwhksf2rsdOAvWt","st_dist_05":"QlsduyXchJUxxRycffF4Vzx8","st_dist_06":"gQcfuNixsUpWk4KZirxp9h3R","st_dist_07":"0rbEuoD021EEjKpqDHF3BqFz","st_dist_08":"AJOUgMJH8AHRr2Y2KmA6HzFP","st_dist_09":"RP0meco1HG814n9F7DkH64Wh","st_dist_10":"6O0kcdvfjLH7y3a2lLpz8Tbe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nXx8jAtcI2acarwKe9wdiPwuxQiMEMViYxtgpHHdgMfbDBNtb2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":178,"st_w_id":1,"st_quantity":20,"st_dist_01":"pTXvUrJzvR2Aek57ebEkYGeN","st_dist_02":"cxD1QBJyl9ivbffQgTQUUeMW","st_dist_03":"oe54HRrz3aDNaxa0dBUZ1GaZ","st_dist_04":"9Bc3ZTQ0cHteL4xiefMqza02","st_dist_05":"eBt6cZIRSSD8Iz8dzN0gAmBa","st_dist_06":"MqBtJGo5XADnOxhWPVIgp2if","st_dist_07":"8JGgvij89J6GW4f3QMjCCKOA","st_dist_08":"8FhXIHIjhZXxTNFvjyC3NCe7","st_dist_09":"qlnEJERiaEK3t5P391FiKKSV","st_dist_10":"pYtjw5yyDyrsqYMEiJ1PA560","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ggGI94j7n4Z5AA2rQPu082qXsBifuJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":179,"st_w_id":1,"st_quantity":42,"st_dist_01":"Qstcv7PEEiz9rKhlZgB8dRmq","st_dist_02":"PqzN61kfJiCmtjvj3axS9TiK","st_dist_03":"hKFKbh55yX36xr9n30yYzaSn","st_dist_04":"8uAfQAyDQoghX2JRF4rMjRtf","st_dist_05":"7xkKWYGFxSmIzPPMdELb9QkA","st_dist_06":"smZI9MRqKRf50TMJRSibQPla","st_dist_07":"yccuqxZD2zFeVVj5FV289MPb","st_dist_08":"7l0KLW2pLDBkFidjR00DY4TQ","st_dist_09":"tlB7zNSSWl2WvKRO2UFUpmzC","st_dist_10":"TeSe68SjiQTyZFQmikuHz04W","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OoU8mWz1pJqQM3PfimTzfOYaOROvl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":180,"st_w_id":1,"st_quantity":65,"st_dist_01":"kMPHkBx4QzBxqlHO9w2qUwLr","st_dist_02":"DHOvrsDLcvjvCC60vBIkwkLP","st_dist_03":"f4Tfx1vd9kUSH0bJ29oXkWKY","st_dist_04":"qdcKFTXKDemOSNZXYUAqarm5","st_dist_05":"fnFv5vGSEH8qztKCR4du3O5i","st_dist_06":"dl8PhANYUqMMcaB6izVomDGe","st_dist_07":"sAufGqgpcRlk5JntvYXtC0LJ","st_dist_08":"RSqYZulMAgzutcDeKS7gbAoC","st_dist_09":"Qd0fDdpEsOhVFn86sAzR5DUl","st_dist_10":"akPWQ3MQwzvgfvhEXw4V8lJm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QJiIAVbppef0yGLjLZP3UMOsGfkXaoOMPvUPA5zD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":181,"st_w_id":1,"st_quantity":76,"st_dist_01":"fatv8ZchBc7smS1EkfRwODfm","st_dist_02":"bO1wr1skbemBFw54szymUgvn","st_dist_03":"CaxWbTkWWW2SGUB4GI3TONGb","st_dist_04":"kBlWyMIxKtqOs7TXT2SD3Lm0","st_dist_05":"3gCaLcyOMUzUWG8E2Hnbfr0F","st_dist_06":"E4g2Jc0xUmlvVogYTKwfK262","st_dist_07":"75N37BXFuGHchgQDgMFqpMDT","st_dist_08":"n1KvBOaF4B1freEzRAJFBp9t","st_dist_09":"N9fwyMVNfHuYI76QiHcUOjjF","st_dist_10":"udBkvNYl4a2cNoZRcKwbHvqK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mGMR5FeGQ1KLM6ep41zYiqfMfXvpVJMRPlqJ4NM3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":182,"st_w_id":1,"st_quantity":20,"st_dist_01":"oAG7b2gRLf4zAnXX1igYqOCn","st_dist_02":"ea70bto3p16p5fKTNRlEQHBf","st_dist_03":"fY7uHgM5RLOGR48ZMrvNsbja","st_dist_04":"O8B1AyffQZUtn99C44rYR6yE","st_dist_05":"BVFoPw7C1Nc1rr1PrCevnlFk","st_dist_06":"HRVeUdyXHlwziDbMza8ZUvov","st_dist_07":"2e3e11ImFWXSdISXBHGdALeK","st_dist_08":"c8LNSIZPNCp0FKJipGdryx8b","st_dist_09":"yFWu39Zx6BHogOGfUJ7Cdgpy","st_dist_10":"iihH6p93THjy4g5UVKFgxtbY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HBHUd45dWOvTx8cktZHWWD03SikXw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":183,"st_w_id":1,"st_quantity":23,"st_dist_01":"4jxI9lC2Jdw66VUQPtm5GNHo","st_dist_02":"w7DDjhttmlbspQQnKjR3lZ8b","st_dist_03":"5bf0tDtQnPGl0GbjL75laLPS","st_dist_04":"O3apotyBjG7XzJ98TafjjX7f","st_dist_05":"uetPfoER1hJTXRXx7hRJy7LA","st_dist_06":"9Rm5Id6oOLDjDNr28sWh9Ngw","st_dist_07":"CMbu53ZgqyYW0Xb2gWH266oy","st_dist_08":"QbD6fyehF8Kf7O8rMRZpI7Qo","st_dist_09":"UOjz5GZfzrNqqM3uJ2ZMnCtu","st_dist_10":"zJdq6nFUOwZEP1uMpwhV9aeC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bPrwaz2e1jXYR6AR4x2YdzSA2JwXdUqXJU6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":184,"st_w_id":1,"st_quantity":55,"st_dist_01":"vTJJ03tKlX3eJYgFaWIiLaXy","st_dist_02":"xBgU0a1ST81nfOEE1ajQvJJ9","st_dist_03":"9AzXVu7IlJcVDGeyTXhL0SO0","st_dist_04":"IjithqQPz0IyjnxVv7jS1rnm","st_dist_05":"CoLreheLWFN9v0zdUVW0zTAT","st_dist_06":"8qNRL8uCycBu9F5MSiqIx08u","st_dist_07":"AQlyJm0RtRFU57IbboyuVrNa","st_dist_08":"ib9D4eLGnI6f59RiWiRP9V5M","st_dist_09":"rrBMsbtzWIaYbvSIcbnv2f8E","st_dist_10":"gt4p2Xs28cAFseM1jJPYFy2a","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9eURb6FN4twTFbCmhDOYAkrCaZJvhuRHYzqY3dQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":185,"st_w_id":1,"st_quantity":68,"st_dist_01":"t2PLmhPgB87tDHqzC8RMaJ14","st_dist_02":"mjGE5exBFdEnxHHHXrWFk03x","st_dist_03":"cNqSoM9LsnHaAG0XbBr58rYn","st_dist_04":"sbKAjWKU2jY2SkXXM18WHKh1","st_dist_05":"J7S3iJMstySkSUBVKWozK1Ji","st_dist_06":"JPfTzmUKPNX5TYzuNAfHGZH9","st_dist_07":"hoGKER1gYLze11ZE3TJLw2kz","st_dist_08":"97y9mXNRf0xXx4eq9LkiJ35F","st_dist_09":"RuPLehcJe24atV1eWLcNs62i","st_dist_10":"qsvXD78AR61IjMREOPhp5U6n","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ob2svR5PSUyACIzDyYmK5M0cn5jPTABPStk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":186,"st_w_id":1,"st_quantity":82,"st_dist_01":"gQRh8xUpI1LL2GqbcPVlfb5f","st_dist_02":"b9FP4SVtn8patVBA0FXj2HQN","st_dist_03":"hCVKSUDQwR2pcIz0IZRNDSum","st_dist_04":"RyH70ndbQJW5PLYCttj1umqc","st_dist_05":"u7JvGbk6J6TjjktfvlmQIqrH","st_dist_06":"X1J9REK21Jd5MrTaOkAdf2eC","st_dist_07":"r0JUKpWoyH19w8pUFxqeeXSD","st_dist_08":"f3afd27AFPVZHSADGWKx4iFW","st_dist_09":"Bw84YCLXVHoE3qmCstw2h908","st_dist_10":"qd5v0SKFDWB5SLQlIgA8QSUO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gfju6CSE3gIdak0otxWFKdM8odzovDb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":187,"st_w_id":1,"st_quantity":26,"st_dist_01":"zi3q73OjPAQPyKUH2cOVc37s","st_dist_02":"0qnnLk3BuCIafJdo24VP6sXo","st_dist_03":"YW1zZCq2UBD6ynajMpeunaid","st_dist_04":"kAA7BKiDAhQHhBjoHHDsmc0S","st_dist_05":"4ipJ2P1TOuddgSXLgZLxbzqO","st_dist_06":"jvZhWFScTESVgf1EJZL5cuAH","st_dist_07":"Bds2STYuZTdXTBLvzbyjo5kX","st_dist_08":"QfB7KTxjIy6sKnjT0aSEdJkL","st_dist_09":"o2ZOiGV7LdGuEYZKadQAKtBT","st_dist_10":"EBh5tPFSYcFrtYUyQETEKBk6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5VMAWLzucO5emrVCoqIQwAvQDw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":188,"st_w_id":1,"st_quantity":32,"st_dist_01":"Znc1hyLVUEDhprUWD6Yqf4Bh","st_dist_02":"DqR0MdTHUmNPQMQpqM9bjJie","st_dist_03":"PJVwzGyjQB10Yym7ofVLD3R7","st_dist_04":"F75ivSFKrmJBYi8FZEskEXuQ","st_dist_05":"XxvsKfZoH6Gf2VP0qQ0vWPx7","st_dist_06":"ED8i3n1J2VZwOuk7Jyty3pEY","st_dist_07":"EIgV2TE5vPNaFR5GKwRHJ5if","st_dist_08":"WA2K3xrNGJtWtP6GNTVc01Yh","st_dist_09":"48JuC8JvxYD0HZt9RPAewofv","st_dist_10":"Tlj9BVMvfirO25Dvti63VgBg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4NRJJerBqMVRlmMDwomRlJ2XAWsZhdvi9bZzElLRRAzjwgkSi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":189,"st_w_id":1,"st_quantity":39,"st_dist_01":"UJL1FJWAjCfdz4pp3O59h7CQ","st_dist_02":"pfiRVlZFQellh602dWq10IpP","st_dist_03":"Xzde4AkI75Mf4TRP9AySgFsQ","st_dist_04":"rVWfsBBlHTEG2el7RZdRT1kg","st_dist_05":"UCX4sC1Rhy8WUHZFkvAnSRbF","st_dist_06":"jIyPbohCQoS4DsuVoGqMJwyu","st_dist_07":"hOLM7wSp1VvPKVncWnG8UgS8","st_dist_08":"x5oqZQ8tSTDEjrluDkxSAarR","st_dist_09":"Qo4pp1UOG1DwD3nQfIh4tKNe","st_dist_10":"73Ajz5K8drgu09ll4y4HHgck","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FgtKdpzeizB48DPcWiglyAtwOmeZBE19rHxFpHh2a5B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":190,"st_w_id":1,"st_quantity":63,"st_dist_01":"vIC5mdnK2sBfKjvr0E72IuwK","st_dist_02":"9KiIT2qCdLZUr2Gx9CuClX8S","st_dist_03":"1WnaR3urOmT25g02pDVTszTA","st_dist_04":"p6aHdqbJ241qcAeZqeV2tVeL","st_dist_05":"APbnlxS7o8k4E9uDwHUHwA8v","st_dist_06":"SruBqufa5Vdt15tzW1Pdf9ZD","st_dist_07":"YbjCihBs8IELy5rP5atQx8ux","st_dist_08":"FTVeP6tMjpxXHssFCX0kk8Ys","st_dist_09":"fIc4v87uiHxivyt26G2g4ayz","st_dist_10":"gGZJnXByinYOHDLy6r39yMs1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"j02qKz80cLCQxjMUTnRARWOxn1oD1XcVzPam9Wc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":191,"st_w_id":1,"st_quantity":63,"st_dist_01":"jLkijLvziLo330llWCjZ9m87","st_dist_02":"4sgGFCc6jthBU4rWiUCPOnCD","st_dist_03":"bEOFoDTOKTFCaZuwcfD7QZMy","st_dist_04":"eC0FVhAGKyrqsEQlULlwpdiQ","st_dist_05":"nmeiDTyLU3lCXpx0wb7qNFLJ","st_dist_06":"I44ny8RKgx2nkQld46f5AmQN","st_dist_07":"m798ka9mxlnNcJpnVWwSlLzN","st_dist_08":"6vEVtBLBLSt3NZjLBBIrqyjW","st_dist_09":"caq00GKYDx1ZWfyz9utPKEf3","st_dist_10":"0Rai1Ymkruph4SGQwb43NePr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"okAHzJpLUMw1loLMpsueoudGBU144CGzWzQkLAnGrqksOVupDN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":192,"st_w_id":1,"st_quantity":43,"st_dist_01":"KNDSfCAgZAIPmMEf0ftmKX5X","st_dist_02":"UoXBtmKdlS0jcHkNNtj8pSP8","st_dist_03":"aK18MzFY5fs2EKHAQgXc6mfj","st_dist_04":"WzgJF0GjR2VnNzER52dZU9Eb","st_dist_05":"m5aPTv3eOhbO3VmP2opsc7Bk","st_dist_06":"iEDfArlCMEoprILwIAMnI2F1","st_dist_07":"MBKUWldKsCdReq7amVdCVZME","st_dist_08":"xiNvGVH3nDmI6WFTevSd0K5f","st_dist_09":"k4Tnp3oSRXhUVTGy1sDROwfp","st_dist_10":"2NtaTS5hkzgezMZxbZspDNM8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"y7fTIl5yeUqREegx7oR3TAHjkYufEXbx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":193,"st_w_id":1,"st_quantity":92,"st_dist_01":"vmaxBSDI5IYGqTA32N8aHdOJ","st_dist_02":"BpbbW5Dm5dxe4zYkRYI8qs9y","st_dist_03":"KVXTUG7TL1W5HBVlvA8GtTpd","st_dist_04":"jgm4Yrc4rfDbcRtqiYSSQ9MR","st_dist_05":"QCqpKHRtjUCdF5RaGFxeHQVT","st_dist_06":"1IhJNwe2RBKD1nIgEdoxt1Ft","st_dist_07":"jOvh1jJ3rGAUF5Gf1fDt1RQr","st_dist_08":"TXglzj6PeCyFtjizmBh60e7u","st_dist_09":"JAptGtxkloFj1IHq0Ir60mIp","st_dist_10":"SBboZqm8XeiMenlm7AWgXgwx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fLOXOPRS0ACICURPbOWJcy8c41ecwjjH1NoaMeyumw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":194,"st_w_id":1,"st_quantity":20,"st_dist_01":"ItOaLwxCqPEIzxNA4Y0BQUlu","st_dist_02":"V0aOGvWg2531uP6lT66ws3mq","st_dist_03":"RXUEvvfq5gXCakOq9V2CGWcr","st_dist_04":"VR6chCYiLVJRSAc1R4lpC6gq","st_dist_05":"oA6wALc02XIzq2fccMBAVz7j","st_dist_06":"l8ZdrpqEZ7TLUHfdFDPiUMJH","st_dist_07":"SztOcxcAaNfo0CxqalMrWDKL","st_dist_08":"Qlwqm3GC53Oz4eyRy7hvaUxK","st_dist_09":"OoI5dyw6vy8EjGFs76QQfgT3","st_dist_10":"5s9Fcj3KN0X7IZBHd0tXdyll","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SMdiybwK3bEAGUadWN767RV17Li3mZ0wdE3ch"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":195,"st_w_id":1,"st_quantity":76,"st_dist_01":"nb8mmNS5lLJskY9Y5kcMT8vo","st_dist_02":"uMVfpqpdZFLAWUUzXsHl237A","st_dist_03":"qxO5q1N8gqpTrkMoSiN7v7ss","st_dist_04":"eRc7SdGxchEfzBJI1pT6pYnj","st_dist_05":"c3gbJORt5SWt2N2JWZqx2PAF","st_dist_06":"WWFnL9pBMnFtbCK0e8Y1xP2f","st_dist_07":"eIpZTzENuSs04i40YfGsfjuF","st_dist_08":"T8OhVU1F3UptWrUsUbmtc6rY","st_dist_09":"5osXPPkHVFbrk4d5JEZq1Sq7","st_dist_10":"BESYOQhZn6FNlRhEVox1JJT6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"A1q2S1dnM71th6gdZlbfpYESE0m3cBHZuXvQIfAdzu2KGz3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":196,"st_w_id":1,"st_quantity":60,"st_dist_01":"tLkQgNr2NYgmYCddHeFmGlG2","st_dist_02":"NLcBTyHADO4knLFsQEtzbedk","st_dist_03":"H5NNy8Tvj2leYBeLxLwdmlHM","st_dist_04":"MW71YcP0diPqtsZ4BbR9bwDZ","st_dist_05":"ESGESLeoEvbb8NuWeJJN4XbZ","st_dist_06":"408EEwmEN6qa0In61t0ZSsEp","st_dist_07":"8IhhDOUtVRRRtfnMrI7TcftF","st_dist_08":"uuraMERlYP1iQJmD1yjDLuxH","st_dist_09":"hRpaqxiPLurR9eh3KuqtAJ5c","st_dist_10":"Igy7ykCqqkXxvuymTljqE8q5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AZgyFeGXNDlDMNoTDdgbcmAsciF47R774M8W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":197,"st_w_id":1,"st_quantity":41,"st_dist_01":"B4imyBACBCI0DL8ttySb8xec","st_dist_02":"rak69gZ72MDRWBQPiRSqF31m","st_dist_03":"v20wpQ9TSDSgCArKJ5923cL4","st_dist_04":"Gme1LowTFNtxTbrI8lAfsnoW","st_dist_05":"ZivL8WWfjVB6cW8HzfhIBxou","st_dist_06":"xCzmIJHPxLKziwYIJpfOPjNq","st_dist_07":"O5bvDNkfgdwZAmTJc5fXl13u","st_dist_08":"eRnxX1H9PiJevlJhHd18JWZM","st_dist_09":"fouHgHE2LBZSqkJ3fNyrmBH3","st_dist_10":"rJWkLrdnHwHj0gBBg6Wievxk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"S5zuBbatdwHqmxl5rhZnHOyPbg7p4eu5IMRhdKT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":198,"st_w_id":1,"st_quantity":94,"st_dist_01":"ZMX3PbvHXZGPPoWmyXkhuIDM","st_dist_02":"VF88lhFMhpQ7FxSq8LuCFWOX","st_dist_03":"PqEkF312TXtZVKq3rXQh58aY","st_dist_04":"0Hr03O0ilPEtJj3BDuNtN0a3","st_dist_05":"ZOseHpQwmOCQ58OU9JGaIxyC","st_dist_06":"q5Fc1j8Kz784jOgE0AvhuhTt","st_dist_07":"WdPzQNQhFlFSKJ2imbmH8u70","st_dist_08":"u6TuqMx9mB0D9d7Xt34yZLUI","st_dist_09":"JOeJkBdrzaU4xXXJoCJb64Jm","st_dist_10":"UZlaelgrGUdTwJPuWpF3SAuN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"onZWMlfNoI8OeR9CQWCJdhvmShU7pfQCOekU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":199,"st_w_id":1,"st_quantity":79,"st_dist_01":"znlxHxeKvUkt7WXv8ZFOzafk","st_dist_02":"NWARU1VRpZAK5Tn2upUVX54g","st_dist_03":"dxtgvMk13uwIxpfiXJM5vhPY","st_dist_04":"c9OK9TYF7mTjY0rsJkwqsjdx","st_dist_05":"ki6VnKPXe0WRhYtSY2C6w5ac","st_dist_06":"bHYmLpSQJkh5W2NvqyNhQFKv","st_dist_07":"NE3hjU0HpY8V7OtAuJ5y8GqZ","st_dist_08":"MJI4FOc8LYOASXtk8e8ytaq2","st_dist_09":"sSdkdPZmf5vBopAuG4HjWoag","st_dist_10":"HMPNeoBRcFl0Q7dQipDvBH06","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CH0pA6CyZPvwMzX71tlTXvFU6G7ZBeK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":200,"st_w_id":1,"st_quantity":32,"st_dist_01":"PpGts4QK5TzneiJt2DWk3AeY","st_dist_02":"yUtFSYVRpkqqSCpGoUUVFniB","st_dist_03":"OZtja5TsVewIOuUqP8BsN1Fk","st_dist_04":"G59wWkNb7dpNWLCX5A58XqUw","st_dist_05":"7xXEkUwGtjweQhbE8cDCgl67","st_dist_06":"iI6pSXVvgEAHOmUlPm1oUCpG","st_dist_07":"oVQKa3R7TfjkpdMfH1I7RwME","st_dist_08":"TtIoSP5483flpEk7LAx06v1m","st_dist_09":"LfAKTKbNVDOw7zBgSIVjXORt","st_dist_10":"AnqUWjr9lWEhazqX9QvxM1pe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3dhVeuC6TFAObEyBBx8nRjXhRckvK4H7uj6ug88ZW4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":201,"st_w_id":1,"st_quantity":91,"st_dist_01":"YNfe1hrCbSfyGKwSEAVitAmV","st_dist_02":"kr2iajuOeGElIUQkxYuBaJen","st_dist_03":"OyKIlHy1C8YUcWGADSTMhP0u","st_dist_04":"apaGlzIS37cBiCLbBTgWa6hN","st_dist_05":"HljQAUbmj7rAZYweF7Ibd9iC","st_dist_06":"rtKiTs61p775D6HDTOtDTuxs","st_dist_07":"lnJ7VjRwdr3FCl97nY3ByFHN","st_dist_08":"iVYpU2rTbI9OmnNsPnzot5FL","st_dist_09":"AR00obymjg6GmCEQfQVhVAnV","st_dist_10":"OQGv2hF76EQIJb7goirfogaI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MNzrQwdNWPN9M2Fhq6gJkbT4NS78RtrwUrVAZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":202,"st_w_id":1,"st_quantity":12,"st_dist_01":"XhcudP7cqWqP2iuLvMgoNX3r","st_dist_02":"CxLmOKpxlo3ks8fN4teiM9yU","st_dist_03":"0tZVwQUa7ZMmy5Ty2U02t337","st_dist_04":"yiwRvtshiX60kTnqPBQHYPpW","st_dist_05":"06qcYijghXxzxKwZr7x3x9u9","st_dist_06":"Kd205Oi51ZbpEHcUJLwpkaxl","st_dist_07":"cDUWMmbBbWYWkaYBmxnuMqTA","st_dist_08":"uBfjwi3ceX8xndrnnrZUXqvS","st_dist_09":"3jh9mShWYueZLFGVRnyUH7Pf","st_dist_10":"yWodJRtdOv2unvtB4TDtbfpP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zDisfsfuYQAYxnINPTGfw0IeAidQZVNuf0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":203,"st_w_id":1,"st_quantity":56,"st_dist_01":"iOqfdhtTnIKgk46Tk1BdJKJK","st_dist_02":"JLzgAzSEB2I733Lh0Z1xBh52","st_dist_03":"stPzYApx4ZYZ1VmTc6xH8HBs","st_dist_04":"tYJfKmVxw2CIakBIoN90OOQc","st_dist_05":"vJL8vzp0fRsMbppCf1ruEczZ","st_dist_06":"yKv8uxxDNxROpNe7hU24IDZ3","st_dist_07":"slmkysxNnIptZKZwFo2jsaNU","st_dist_08":"R0qj30CwRAUfDR8pKUAH3AzU","st_dist_09":"omi64l1bF5v1pCOdq9lQIF11","st_dist_10":"z2hFFKtgXtoygekPAyk3nrdo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5257F5hl0cSvExTbXzx8YB5PWsy3ZpMSB4krtz7wDr24L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":204,"st_w_id":1,"st_quantity":13,"st_dist_01":"kbqdi5sEGJxWdE327ACqR2bj","st_dist_02":"tOts9GhsyMbjaY7q5R9cQFTn","st_dist_03":"kpsUQrjo5t3bBdqtV2et702j","st_dist_04":"WsGgAeoqbVa2bk3ExtSyoACg","st_dist_05":"qxGEjSvWoVdAXlot3qTaNt6x","st_dist_06":"SFjUvBhSahwVoVUPvbgyozS2","st_dist_07":"cB0RyAZRXRLmajT1j4UGWFLt","st_dist_08":"UwUe7maRfsxWs7Tn5dJkdxNg","st_dist_09":"p5bviKf3Z8pWo89aJXlKXcyD","st_dist_10":"0Dogo2UCGmfpPN9FBYWMow0A","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jr3O4uDYL5Mu1inxGnOIw3o9iBwlCMhc04txCHK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":205,"st_w_id":1,"st_quantity":59,"st_dist_01":"iX2G41geyfkw2CG8GhAuNoAx","st_dist_02":"Sqxtjm0Tw00D7MgTervENs7m","st_dist_03":"qd44g5zc89Je6XXciDfB94xS","st_dist_04":"FPROKqaUzchwr0gcPdPZ1CCB","st_dist_05":"TIUduvbLtmgWS0RuQ4Srmi52","st_dist_06":"rN0F90uWJRWDbFCMrAQJZ9n5","st_dist_07":"WJR3n1MRrIVz3K6KletyiSJs","st_dist_08":"v3OLu6puLkmZGxMIpjk2qYTV","st_dist_09":"md1G0Ddy4tyMwSnWf5qmJxgL","st_dist_10":"RTNDnnjddijv2IULYwFcJNzv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ohk3aGzKdDBfrPNEyXjEqS8lyTBemnP9GlS4D5h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739235,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739235,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":206,"st_w_id":1,"st_quantity":95,"st_dist_01":"tscjlPFvlZfdcviPF4Hj2aPB","st_dist_02":"9wvCXAwF0l3euQvBRJCX0RsP","st_dist_03":"6I6IeK6QVOoAE30SekDxPeKw","st_dist_04":"rWvwgHmrkJS09tKIXp62Nh2D","st_dist_05":"1iZNCch6OR3RJ9sRASZ59Pzu","st_dist_06":"7iHeq78pPwEslmgZWyATqeKy","st_dist_07":"BegNy1g7eO52SYrdfy4oBaaQ","st_dist_08":"7SCKNddfbG7aNM3EPkgIkASj","st_dist_09":"m0N84o6yjIPa3PQ0kNm1cGBJ","st_dist_10":"bsRvpvFgzOk5lWft1eUo3htw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9ZDCEhwVDpV7C3YHdufe7hezkhFeYgvz8HjiSOZupJB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":207,"st_w_id":1,"st_quantity":77,"st_dist_01":"yDRP0LGyxwuBHoXm6TNxgphu","st_dist_02":"CF4gCHqkiHSbmozs4ff7FFzA","st_dist_03":"u45zqyvmk982OBnwSvakYNel","st_dist_04":"kLpmInjJlRlwIhLxrTIsuUFe","st_dist_05":"f6brDKIe956fwR4deUjNWrnT","st_dist_06":"xLBZbMpgBoFR6iM5dtOho0dg","st_dist_07":"uLYgCGhFMXUIKn6ZVtY3SYh0","st_dist_08":"LREqq3kZpDB2XjZwZNQwg5fx","st_dist_09":"cViByBb9ex7eKVnFoGXCfTkl","st_dist_10":"4mK8X9355BmOcppzfTPsPG8n","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PQntFgaSl6o09i2B6AsoCy9Nhz3W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":208,"st_w_id":1,"st_quantity":66,"st_dist_01":"snvK6QKGwxUX1P0K3jsDs3J2","st_dist_02":"deYNPQeJjZvNqxN0vQlP313E","st_dist_03":"nq6MSmOk5lXaqfSRw3GCc9qg","st_dist_04":"iWZM5EWb7XB2fkguWlh37LOl","st_dist_05":"8Y35ny0OPy6SKFxEujLKMEhE","st_dist_06":"1fS5uyvHjvRWfWVhiYyEMDkV","st_dist_07":"QqFHESMmAEbN1Kubuf2tgNWi","st_dist_08":"fxCeezzMQXYrTcT29eb0m6Yk","st_dist_09":"ih6e4bxWwT95aCEFXQJKMUQQ","st_dist_10":"jetD2uSOyOBaCfQfC4dlIKKQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3XrUIONZARmWY5OM88kS9rHVi9BSk6ZAUjU2C7r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":209,"st_w_id":1,"st_quantity":83,"st_dist_01":"YXMmdAxeIEMWYO5XhNXpoHsY","st_dist_02":"byWfgm9SlX1P9tQPgDyn3Y8x","st_dist_03":"rXpEiMtnNekkJIpgxBspGwPQ","st_dist_04":"MUdEbGXVw1C9FY9sF8qHVopo","st_dist_05":"t5v48j4QvX0EWfcd9JdkbSEc","st_dist_06":"ICwq28FMQgTXWXf7lv6Pi5E4","st_dist_07":"0YIqZlVhtK8BMz4jYeGGoOli","st_dist_08":"oyw8FMMkQdvIeq45J3fPhj7K","st_dist_09":"1YIBCz71vc5sCay7cSqcBp0n","st_dist_10":"0VdWjKoXTmCNYC8UKOWkKYzN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FtElHBVq0CGINmZLTxzJpjUjZH2CQ2vjxBz9vxoiZAA8b1X5W1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":210,"st_w_id":1,"st_quantity":33,"st_dist_01":"lHN5FpxLIi7GldWg93sKn9nH","st_dist_02":"t0Uthk3vlJROSa360Mc2erhA","st_dist_03":"KnpcNs8LoVvIRM6C4DRVDtp6","st_dist_04":"dthz8q5RknIImwRXHTgvnvfw","st_dist_05":"y9KDBmMlSKdkDtRbjJ1gRMzN","st_dist_06":"tlMZWf0Bvjq1TGqZDMB0xaKS","st_dist_07":"JLlGceUDKnea8WRGcZmbTnDH","st_dist_08":"wLuH1mWnT4LMXBlCJZdysS08","st_dist_09":"PIuw2oauF0tvpz4hnsCWb4US","st_dist_10":"FvDIiPrAOQPgCxc3zR4Yi6w0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HUVnlZUkrwe4ZHrFiGB7WwXpLkINTkBF8Phfe99504ObGVOk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":211,"st_w_id":1,"st_quantity":32,"st_dist_01":"sslpzFKrrdhR9WlpWITu4T8q","st_dist_02":"NucHbrk1DuHm5g3ww7ccEcF0","st_dist_03":"LbgWpYL1ALuz4EQsfm4hL6Yj","st_dist_04":"g3kVsMClkPBL4d2f1uiU1GtD","st_dist_05":"hBE78syKHoSKSzVA7dZLV2PA","st_dist_06":"cM3aaN2njgaKmH1ynibedsN9","st_dist_07":"wxo86XsqsYrIs1m8CR2CUrHo","st_dist_08":"tSqhd6Vs5xfbUSwgxmoQQWcR","st_dist_09":"WLLAguZC8pr1hJAlyK1NwNOT","st_dist_10":"MOuKHHt5RBXPYPmlyl6HCPjQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lbQfiqmhuxd54yDXTL87cQowdi39XTEAitqoUvNDLfrzCZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":212,"st_w_id":1,"st_quantity":68,"st_dist_01":"OcHWsFYcCKFMeLXdOeaMWQoh","st_dist_02":"vO8CJ5CPTj6tDbvSLzCe1Rz8","st_dist_03":"KPx6jLRraniF43XBZngNDcw9","st_dist_04":"Eq0pejFwebmeHxZhBDVucHLb","st_dist_05":"FjrVfV1dIh631IQ6luJhYbcy","st_dist_06":"KlCnmuS1OgM9BxEv3zB10Zfz","st_dist_07":"fpCHMdwD0FcMpf9MJGjz6lf0","st_dist_08":"O92FPQ1mo2FDd489RqrJZeox","st_dist_09":"ScuFbEAuSomlRcJWs9TQ4SUu","st_dist_10":"8CS6j82QeHk1sVTo9oRfaO18","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t7ES4dgaC7xVp2O2dnWNh1ykFfWuhdXRaq13"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":213,"st_w_id":1,"st_quantity":42,"st_dist_01":"hvhWzFDcAhch0wVToSWbP5fY","st_dist_02":"kwjEVnLz4LVd6CKac2XbNBhU","st_dist_03":"NRkLmPPpRP7NWqn3cWpmeiLH","st_dist_04":"sgyw8oBNXxAOZJkyOXKr8QAK","st_dist_05":"liVeZFzix6fREUA3UEvuYrQU","st_dist_06":"1Zf3tuzqQqDOON0dQMccqq04","st_dist_07":"Vd9GljEVipfOD57VtbDNHTn2","st_dist_08":"cnoUKQ2A92EPfLses0krOpaQ","st_dist_09":"YKhwoETjVY2Jh9v0iITOJGqz","st_dist_10":"KBYZcOF7pwPPVS9f9janSDld","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"udKSu9ULIzNu2aYrInlkifJzP3XKTBvs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":214,"st_w_id":1,"st_quantity":26,"st_dist_01":"CFxcURqdwJGIkqItFtS1gXpz","st_dist_02":"58GjtaVwCyw4O8ReO0PzuB8W","st_dist_03":"D3m2NJ9UDUU6HPp3eqecyOVN","st_dist_04":"elwnPhhy6ZFGE0pAVoTlGBgP","st_dist_05":"7srbGVVOgsah6lMjsDNFu82q","st_dist_06":"1JwCVKC8UOnKjzgguMMz45m3","st_dist_07":"do6FpI6wgAERMmLAonMkjTtW","st_dist_08":"DfCpHljjMZpDxR8ED5jGfYZT","st_dist_09":"acyUayhNfMUXQA63N0zXszjs","st_dist_10":"KvzrZ2jyRHSd0EYHqfGC0QA8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hmZt1njw26QuNoQqiM3lPYBJvBEB39rvoTaKjuwLAZDaxZ1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":215,"st_w_id":1,"st_quantity":65,"st_dist_01":"EPbfr7vxy3SP2HzWX5nSsf36","st_dist_02":"CqCXMjy5pL1mn8kwOu1I3wKc","st_dist_03":"SuYHajL2xRfYCZkGq1Vj2DIE","st_dist_04":"YaBqSVtYFp1NmD9UDnSBQ5xm","st_dist_05":"yIXIMDJdS8pI1pOWOeJSsMhp","st_dist_06":"2FU9xFVBUW4U8c7iImnjLYeT","st_dist_07":"PQAUPJdn3ZkDKZPvsirz4i7O","st_dist_08":"6sgXMxlcfBNt8LXEKZJcXtzm","st_dist_09":"5shwu8Q0vNHtmpE5xqqTlbP6","st_dist_10":"VP4yYfgdlCJAh9S8X1PL7eiT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5fUgitR3o06oSvf9p5neFheLSMPUxdT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":216,"st_w_id":1,"st_quantity":89,"st_dist_01":"s9zch2fdb4AXLBKQ44f0IIsl","st_dist_02":"Wp99LemePsEnRolmzQV1CQlw","st_dist_03":"gA2KiLwkzxfJVrTJRPPx12Bh","st_dist_04":"1M84Yo3OxJvSCuZiFfhV87hO","st_dist_05":"YasEYE6Azc6QiFYJhdDFWhq7","st_dist_06":"itNmL88K0oc1xpGipQhbKNxI","st_dist_07":"YiXDPIA6gI0renwaY8hiQEY4","st_dist_08":"q7Lo5M7QcBh8oJS9jKCtJ90N","st_dist_09":"uhDPjQWjFmfLv9pVAO3VV4Ok","st_dist_10":"ZDD4t6cCZ5tUE53SDPwTIaBP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v0DQB1APxRE4zNlbjTHrg8ufLxyCnMgUZoWW2Zbn2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":217,"st_w_id":1,"st_quantity":34,"st_dist_01":"qK0CQcjZxuBSeQnrKYJGJijV","st_dist_02":"N9kOAzWnDSz0Y3F2J8kBGTCx","st_dist_03":"NRK9Dlg0sDyL1G2tAhjXY2Ts","st_dist_04":"F7znNkLShpP1mAYg2vfgGc73","st_dist_05":"J7CVeHfcwEJ9ZgPu44jS4e4Z","st_dist_06":"ui6Fl6p8ShodDk7pvOEnR605","st_dist_07":"xX8gtapkVGcmgo1ShWKWgllU","st_dist_08":"DCAJDoNxZwAQHRdJ5rCmFIKz","st_dist_09":"bpUGMyF8Q0rethyfOF2Lq6jR","st_dist_10":"99oxXlD4wDHErvsz8K6EDnFg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FvcXkbsjXg8og3Q9Ygy6qBKhDyJl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":218,"st_w_id":1,"st_quantity":80,"st_dist_01":"IFym791e4doO3dkW3pbgPfIO","st_dist_02":"ZBB4mpNGasdPcizf3pJlJUTf","st_dist_03":"ZcIf3DkVuCCisE9mNADk4Dr3","st_dist_04":"uep4mzv2qMjipEqXE2fKwwmy","st_dist_05":"qJQoCDLC6m0nkR7gnZaX8E1B","st_dist_06":"dyJmDLL1RfK9mnufFZp7w0m6","st_dist_07":"WILuioxfI7vwdDN9tZvckSaX","st_dist_08":"DDNi2RsrDdKJwgbUIzR8WV1b","st_dist_09":"Sp2lfLsZUXTsTkKlkFxBUR6T","st_dist_10":"WKNQxpVRNTLKE2eJlZeo4Dv4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"K7G789K3yWX05JxEbyDZkOIX39Gwu9EEvpVllnCcnG3fkOlNs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":219,"st_w_id":1,"st_quantity":31,"st_dist_01":"jTnyGHLWIZe4k8uMhCu6BHHt","st_dist_02":"WAGp6hXc7oGf61mnAtuHjO84","st_dist_03":"0ZoUz75pb5ntCGutR2lmrPBT","st_dist_04":"DnmnT93VN0OKhGMbMz68cFfP","st_dist_05":"S0LViEBKdwxZJzjhQLmH160E","st_dist_06":"1BTujUYgzfIc09jqihUVZNYL","st_dist_07":"hcYYBOeSGKc7enFpXYqExmyY","st_dist_08":"fzdC9FayokW94ADfh160EeGz","st_dist_09":"lYQ9Vcoz7W866ymRFiTZazid","st_dist_10":"tzLsH8ZSNphZoTPXYuGdmU9J","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Pv01WbaxFnoxMZu7D0gqbocMUAhStKgSbDZXGN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":220,"st_w_id":1,"st_quantity":56,"st_dist_01":"JV5gRJzC8lTAWATC14Txo4nv","st_dist_02":"AsVFC51xkNR7MlLWKxs8Tc3g","st_dist_03":"sjqkJlicb42SbI8EeGMY9HO0","st_dist_04":"YEpXK7kZin6aygQ5kvq58qV0","st_dist_05":"NVbE6qVhFrOHgtfEPwSy99Jb","st_dist_06":"NdbyDSL72CI83cinjZSFBiSy","st_dist_07":"VRgKjnRXXBQhAh0cX8BGiBSA","st_dist_08":"pcjvB8IFQ3a32YCXNxODfY1Q","st_dist_09":"weZBXIhoMKdzrRt77cDYjKa6","st_dist_10":"LWBQiUD55ZrHLu7NYS7GSoFx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qsXe4dWL1c8JlvnmWnVRBAS0UblJcHITMoVNA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":221,"st_w_id":1,"st_quantity":91,"st_dist_01":"7dsiowhYHyGK2iy87Jt51qKZ","st_dist_02":"QTpG7ggnPTDScpnES8WXeWCF","st_dist_03":"J8b00WXSwljVb77yiZSnaeRW","st_dist_04":"Cn8mBYpqsHp4Q8w3GqfAsDVJ","st_dist_05":"XI4uJ9ah8k3yCjRNSLute1ro","st_dist_06":"ohOJsO84EIGy9M6rDmJyQ1Oy","st_dist_07":"pVxVCGZtUQxuYbjaw5t9EHG3","st_dist_08":"9bcmYE8iqgWTDxdjrL1MECZM","st_dist_09":"8nP4IREn7lO7MUS6UCRbtYcO","st_dist_10":"sILtCJVUrVuMoPY0zWKFgS3I","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9wefpFjE7kw3wxyydMAIm8nTZBSkTC5hBypa4mdiblLu6r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":222,"st_w_id":1,"st_quantity":13,"st_dist_01":"zY5NXpuhLHysf3fCDFYX6hP9","st_dist_02":"YmRzCKSE0iiTlt6qSwlkPP05","st_dist_03":"D7roaahDWSLMbrFFajmuLyYZ","st_dist_04":"Wi5AGAM9INTddqA8d7R1eaBp","st_dist_05":"eT69iveLuf5bjx2heDRRB7Yd","st_dist_06":"s7fQUp1tFLud1ZmofxwFC0Zw","st_dist_07":"brkJHkAN8ySueFnijGNV2LeN","st_dist_08":"rbh7VH6VZVmJWIRqHiIQweG1","st_dist_09":"RH0EjOQQICF4Ge3X9XhHIKfu","st_dist_10":"6CinUSJmmhwpi0ItJ4szY15T","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qcb7MeEvmSj22qdUl3EHBH8c85xAIL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":223,"st_w_id":1,"st_quantity":62,"st_dist_01":"maYwMqlM3ZcVOtHt71rjy47a","st_dist_02":"6iWs5ZwUNaCNzhOBsQi5BemM","st_dist_03":"n3u8LwuUmPDLSen2bOaySjMB","st_dist_04":"mtHGnVhz3QhERMZH8PuelSvp","st_dist_05":"XlMl1uIFrsKPiGPWfKuD6yip","st_dist_06":"AAK0Ass7m8crJ6xMZLUCaA2p","st_dist_07":"UGxY9Gvv6hVgMZT78i1TgCKT","st_dist_08":"p05Tg4k6oCT2fhspJJiOeFw9","st_dist_09":"VQViHEjCfZIlnzDDjRrFim0j","st_dist_10":"LAKSckBexsMWIMDanYIa5cyc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cgGVG7MJoxmfw4kZZOI1gY5b1olgZ9qLCVoxjyr9Ayc8Ukzk6b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":224,"st_w_id":1,"st_quantity":58,"st_dist_01":"b9wmpyNcq726LDlZyrp4nm1g","st_dist_02":"MGBvG1rDsN5MAsKNL6DYERw2","st_dist_03":"KlYPCU7S0sdc0DL9nWD20z3q","st_dist_04":"fb0WksYvz12kujvWlz0NqfmR","st_dist_05":"1kujr0mad5GsTqeBmNbtmRG0","st_dist_06":"b0ALH1AiYZIiJNMhTPQPWovs","st_dist_07":"9TjmeTUtiS867bNbO9mRzcl6","st_dist_08":"fDaOCTMPrlhxy3mnsiGlydUp","st_dist_09":"rwyFKFfEar6rjhxkJ5b7GqiB","st_dist_10":"spOivUF3yIB21Fec8MGtBFO3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vqoseSJJLl11anfKqR3JxI1H7u9YdZOZn6mnf6M1LXNDo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":225,"st_w_id":1,"st_quantity":19,"st_dist_01":"NRVZ8vZASf3IXezyHcguSUzL","st_dist_02":"tuYfg2kVDyUpPYV3qGoB4mGR","st_dist_03":"La8Ue9XkK2RE2qtGM6Dmj66B","st_dist_04":"rfD84bRAV73NtyfJzpxR0wHo","st_dist_05":"rIw2nCGqBKWT1eVYItZC9qw0","st_dist_06":"Nl1zOVaeAjm0DROIFAQMVFHd","st_dist_07":"f4AmeDtQ6wnOwlxpkDP80Oj3","st_dist_08":"WjAEESUO3ByMIRYGTzwBdwRF","st_dist_09":"LO1HCoJvq6e4ZsQvEymdk7dr","st_dist_10":"0dS1avtKnwueJSrUokkNP3XU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FPjkSdDhn8jJHERmmzDl5lDybID0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":226,"st_w_id":1,"st_quantity":70,"st_dist_01":"ilSR87GPWL53wntb1oOkcPC0","st_dist_02":"zByYsOxgCQe24bY89qnsK9R0","st_dist_03":"HDVjcDRqjSMG26UfAAgDSJBX","st_dist_04":"ntkypXuaXAWzKkt9OhjEwKwb","st_dist_05":"DJshV2KUyO1Ece9BwFdnohwA","st_dist_06":"H63IlcT1tp0KYN8y9L7k7jPN","st_dist_07":"XnjgFf6qD1zdMuUmBfaeoFgP","st_dist_08":"6E1VSmYgffQkK7K0dUil33o8","st_dist_09":"9oVWG3WQlNcSlj0coevLsXwG","st_dist_10":"PB030Zwcbw5dUO5HVlKvF8Bl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NKuONxxRXMaohjLdkSRcOaAV5N2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":227,"st_w_id":1,"st_quantity":32,"st_dist_01":"fQQY2sLEvyRRg5yna3w7eRcv","st_dist_02":"udArKydOg2DaGZlUhRDkTK1A","st_dist_03":"k4N4mWoGUO5lM5sCzHTfGUAS","st_dist_04":"uCkekvz9dF2mJJt7SbOr0Hsn","st_dist_05":"f2yMAkdQlqqQXsGcTvVVVwVC","st_dist_06":"rOoJ92ByAZtZjZETXR5gX2z6","st_dist_07":"04ZwZ7ttWdVAO6iBz4yKDfsL","st_dist_08":"CN5EVVkx3WWOz4mrUEuypB09","st_dist_09":"rmpNQMrLrEoQecbute5wil01","st_dist_10":"JFTyl3fIPWfT8ciFpzhbawnK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eaMCBNvAeEivq3Zo6lOp9UIPO5VLzoa8gqAE5Q4RMhWoYgMRC0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":228,"st_w_id":1,"st_quantity":85,"st_dist_01":"SrObmj9wmXvKtnDWnWnFPD8h","st_dist_02":"BH6M8ixBkk7ITE9ej3CI3DfS","st_dist_03":"R58E5j2ojPBtUAcqyzEOMHwb","st_dist_04":"y0TYQIdlQOuDdpWVxP0khDYI","st_dist_05":"DQGp7L7pcTjtV0tYexQI8iM5","st_dist_06":"d89sVbjR2kIl60FGHSuxIobY","st_dist_07":"GufSFgPKrDM7oEBLqh6NSUo6","st_dist_08":"5WfhcGTniHriRLeucT3MtGml","st_dist_09":"4WZxZx1eZnhlBUAvmq0S8bnJ","st_dist_10":"q9Q1ZrOEh8KRoxpcKJhEPRty","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MZYJs0n38medxzHtcomvBN4e9ypTs5eJkDgjU1PvYabMO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":229,"st_w_id":1,"st_quantity":25,"st_dist_01":"KZqxi07RjmYtcTSTdAtsTgyv","st_dist_02":"aLAwOMjYX4qJhZWfuwo7936f","st_dist_03":"rGKNUdK5Irs6w8ivjZqMxRYA","st_dist_04":"mlj6GoVvuE6kmbrELREkkLLe","st_dist_05":"J0M4xgD9J3owedo9Trc0p4GF","st_dist_06":"py0MvQt9of2IP3t3CRWKr53V","st_dist_07":"nxOkRRVJfSvMBcuzhs3ZATbZ","st_dist_08":"e9fa4KXVuALyJ5wphRQifWBw","st_dist_09":"lz6XvpKCSVgRj03BWH1YsZMb","st_dist_10":"58uqjwXCtdf31dA7LIsmtYxV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hgAu5giyhrP0dPG9Lh1QmJy7F3nT1evj9GD3sVMnD9MfxBxS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":230,"st_w_id":1,"st_quantity":69,"st_dist_01":"yPMk5P8wlKsTj5TxWPxMfEIv","st_dist_02":"6rNHv9KXJypAhBBfezABVIvC","st_dist_03":"Okxwp4YcvMvH3GL4ePKE7yrk","st_dist_04":"Sl47dtca5lQ2q576XUTVYb1L","st_dist_05":"UD4M9FlprMVVLdnhgw5tWwrn","st_dist_06":"5uWwHGtNIIjZbMDukoSBpEM2","st_dist_07":"Wuq8wqGrqc7dw5sOTWA22cN6","st_dist_08":"lAd75IDRGN74cBAEk0UTiG74","st_dist_09":"nDHPQv0LILNa7gaMgidFEAJN","st_dist_10":"oxeGHdFkGNjPkRizQhSqVzHG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WynjgUT8pjA6QttQ965jgdrYYCpcdQIjcdBFZl6mHQWZAjIpTG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":231,"st_w_id":1,"st_quantity":20,"st_dist_01":"SinXsTF7AqCt2bS1713ffXSG","st_dist_02":"TZ6ae94Cduxe97ZOqYj9QexD","st_dist_03":"MvNyJOYtIo2w6yFwfoMG90Hx","st_dist_04":"AVHvv7K7239sJaw7Cy211RJA","st_dist_05":"i4WYheyYDkSWjgWn2OmKQcmB","st_dist_06":"zcOaeN1iDCrpxW4rluZy75oK","st_dist_07":"XEUrwX7xXinQmRtDLLii6Qq0","st_dist_08":"HfMAufFvhSzmN2tJAdiyW2iN","st_dist_09":"LTEbcqKrsnPWhJpoGUJ2dzMC","st_dist_10":"WPVVivjjwdobXv4QKZHDw4mz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Mh7yNgObrrBkdrscZcjE6kWG86tLVfqu8OozTQMKebJybSM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":232,"st_w_id":1,"st_quantity":66,"st_dist_01":"4M8ICecUz4hSfo2GYZk3as7L","st_dist_02":"c3WfwFVcwCIvpdIdQlqgaHNC","st_dist_03":"2Xmb3Iq3GAID4EzxEHDKCLhi","st_dist_04":"eTxrJ6KvZYbBOnYnJB3rwkVQ","st_dist_05":"d6d1SdIEWTvxYQrGXRWkJULV","st_dist_06":"T9f4Xq5sWEs1tF5YlX6KEgUU","st_dist_07":"Hrfs9JYzLL6grsVRuTstr6jP","st_dist_08":"hOJ2eVB5UOcey0bQ8qHNz8FK","st_dist_09":"pFe4Nl17bNomn9MMnNzk4Olq","st_dist_10":"tkXxfC7aKWPvqRjdJqks8YdL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O1SQUeXkwB20Obqv36ob8y83BV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":233,"st_w_id":1,"st_quantity":71,"st_dist_01":"3aaQ407tNF71F6OLcGZexbrR","st_dist_02":"H8hgspjdqi0XIMdJjQekygum","st_dist_03":"CrioNTmtDxMinVNmwgHwZ9fJ","st_dist_04":"nXSyrDz0JnUfUdPoAQEB9Nx6","st_dist_05":"ObluNXC8koNZLpAQg1uVM78h","st_dist_06":"2gWTRXzpWXeXa7Lo2OZzoVfM","st_dist_07":"BEK4M1Iz9GYLggjxys4Qs5J1","st_dist_08":"94wvicDFIsJBjbqtzwFxCC3h","st_dist_09":"uRaV3G5PVS2fXcWJnrEwypqk","st_dist_10":"1v8tAdJDq3XoByuuKjv2JHnE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OhV5rRsFOZGp5EoriginalqvzAvfIo1b2FGQk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":234,"st_w_id":1,"st_quantity":65,"st_dist_01":"u4aTGRiIyl8Qqz5kr2u8C0zr","st_dist_02":"xQdb38TG0lFPGZEqYEnLlu3Z","st_dist_03":"YCrQaOYeTxvJHGlLX1SMdTqI","st_dist_04":"Y075lRF8WIFbgmhC07YySD8Y","st_dist_05":"JoAW2EutO7QsXg5SOu5epUrt","st_dist_06":"qGn1p3OEOuAHxwI29dLb8HZ0","st_dist_07":"mBu5tTWDmexUPVyrNyBTn4zp","st_dist_08":"UiWAI0o0bqkpCfyDaxBgzULr","st_dist_09":"Oi7Dl2aHfmTczBwVzMeE3R0M","st_dist_10":"dn255XShK8iOVdlB5u6L38FV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TwfjJP4kvxKu9BWnYgAutx4KdUTjeubk4iR5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":235,"st_w_id":1,"st_quantity":46,"st_dist_01":"POvhfZs14506C91wiA1fy18U","st_dist_02":"PwkEHredJEFakG0oAVVNqkCq","st_dist_03":"jgwaGPOaY1QAAHWSmoUjvzvP","st_dist_04":"tvjk5fppYWjvlbpELueDhEh9","st_dist_05":"3DMRINn1BRiIF9TegDBeQZgs","st_dist_06":"rWz00mKVu6bFDEx6jIL0CEXQ","st_dist_07":"R7xxU6OsojeJlS7diWycwMqh","st_dist_08":"M6IUlfSVYNFj4u9Yql6lnuS1","st_dist_09":"bDKUOwwmyDmC0ljNNodS6fGR","st_dist_10":"HLGMlDLjhkUbpLjYyIn4kHA8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xL9LoKPh0AU9VWxA59hVzUtKkO8DnuCuWTlzlI0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":236,"st_w_id":1,"st_quantity":27,"st_dist_01":"J5o8MRDt7nYiNyyBzQeGPfyV","st_dist_02":"UI9XIWDWQdffMPE3C1m1wGta","st_dist_03":"XOXMN6e4pV1ekevgTXG61J7K","st_dist_04":"rUbYIehCLN4Q6fNQfeYyQe90","st_dist_05":"RADZfjpxxxEoTENZyWD4qu0H","st_dist_06":"vJyfHExTCChzvYg8vp11xdcl","st_dist_07":"cpdOV8bN5TdwC15Myo718kOW","st_dist_08":"gzp9GdiO5ZP5DT5HtxAsHRhc","st_dist_09":"tZsCrQlwu4zhBqZTJFiftfGK","st_dist_10":"rCWbVZsa9h1hkf9EXIPQziO5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nLqs4XX6itOMcJX1iZzxYI97SfMOFSirh1KVIszYIYa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":237,"st_w_id":1,"st_quantity":11,"st_dist_01":"aduEQCZ7qpIZ2isLr03FFlms","st_dist_02":"UfvbTfy1fmUdGvMfZ2Wx3ot2","st_dist_03":"XZKJdjBd85DQcX3h5mX72oZp","st_dist_04":"D0DCPaVXZioKeSLyqH99sxLL","st_dist_05":"JDjm2fxAnLQAEZC9cUioz0dL","st_dist_06":"GoyFSsYcK3RdNd9ZSi7t8E7D","st_dist_07":"lfslLPdmpnxEOCHOJ8rcSep7","st_dist_08":"7wMudG3vNHXpRwIF6J0uYFiw","st_dist_09":"mCUojuDWnMJsoAsZCnPQ0ey7","st_dist_10":"INJSV6ypLAESQJHlU87gnpGv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8V06Cmyny3t9dVVxArS0RrGtmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":238,"st_w_id":1,"st_quantity":90,"st_dist_01":"GQJg8qgFvc8nVuE0UUFZrtOC","st_dist_02":"2IqHY81yTVqtQJjFhc2gPJ6s","st_dist_03":"xirIFS5odRnM7UQGWaAvoXvz","st_dist_04":"eOfUGlvRLjbrSwPzA0lXvIHz","st_dist_05":"vDJ6T4KC88MhEH8hGcnWeqIY","st_dist_06":"h8mR3qdNPNXXLxyV8acPUtR4","st_dist_07":"SduFjnnTLI4T1az1vGw3gHCj","st_dist_08":"95lrmpi91uZc8qJRW4QmEiyP","st_dist_09":"YYJsMBEMcEO0JVALHSRKLILy","st_dist_10":"IrBZ6oWxrjCF9YCHOjzpdKNi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Y8R2nLWeyDnOywpXXH7QkxmRtV4PeykSZXe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":239,"st_w_id":1,"st_quantity":83,"st_dist_01":"mteH7CFCyRX4ZgsQUBU9Kg17","st_dist_02":"wPVhWfoPDaPVfUDKKEyKJnAg","st_dist_03":"QIk9Z4hk5YYH1tACPnNwAFtF","st_dist_04":"bK3KkSfcbS6dZSmcBRw9IBxs","st_dist_05":"5iDKD189pxRyAkuPSKxnsQb5","st_dist_06":"bEKGonACqbZ4KvgeDSjfft0B","st_dist_07":"eqh3dNWTRNKThGyyp58Uv8t8","st_dist_08":"JgK0lOJ9pOlR2nsT2BbrNsV4","st_dist_09":"tnRE7MDStvay4wZP7ve9PL0W","st_dist_10":"7W1asDhg2j6xqEbDly0OaXuR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2pZSGCINdsEOvNr9xHPo1AhYPKS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":240,"st_w_id":1,"st_quantity":16,"st_dist_01":"PXLqkKMtWeZKm6uiJLe6mTdg","st_dist_02":"hd8sUOr3r3zvWrsRDEGc429Z","st_dist_03":"ZAa2Q9Nri5jatrSkht5h7JQ1","st_dist_04":"nuGdAwcnWWNse9fcqu7ZlN6q","st_dist_05":"3cvEj05gIM8muzteeZEsUpua","st_dist_06":"Wo8NeHtT5dhH3YI2wwoBpqF4","st_dist_07":"PdiVh9OAvWgQAH1Q89D46hnQ","st_dist_08":"Pxqld618yIxjxXoo70wYA35G","st_dist_09":"VYijmbOsA2uqzQxybotrTz3j","st_dist_10":"TroklpFNPUun1iN8H74jmpet","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0Jkmwsd9xRZ2uQlJs7P2mb4ojq1JabN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":241,"st_w_id":1,"st_quantity":90,"st_dist_01":"ounejcdUUdGQqW4duojOC16j","st_dist_02":"k6jv1CSL6naHD8ih7hkob8UC","st_dist_03":"hTsubLI1go8xwOsFvOsrHR5z","st_dist_04":"CdTg8JPKFHuO0n00KtCBLr5D","st_dist_05":"qhcWJHzi58a6xdjJfeIIn0B4","st_dist_06":"RR1f9U6Wm5TcLbGLPZD0ToES","st_dist_07":"OeA389W8XmS6tz9w8QsO8IEA","st_dist_08":"GEDrJPvR6hMrXaabSTOLhRst","st_dist_09":"NWeXpGZrP9kIuT1VIXOUClWJ","st_dist_10":"qrwBtmvaDL9TRGxELuSeTWjd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ndaCpP8LH9JnPVsvlxmuUyqV7ZcYk3hFSBuDW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":242,"st_w_id":1,"st_quantity":85,"st_dist_01":"2BZWxgQBV1Kr4qFRXnk1Nl43","st_dist_02":"aTlP5GYntSPcJakYailKXrEt","st_dist_03":"EfsWu9c74zmCFDXQLuP3rMhA","st_dist_04":"j6Rh7LVS3HCiOgAYbDBfBrl8","st_dist_05":"D3d5Ly6y8hfUisOHm1lRxLQY","st_dist_06":"iRKOz8OTxTJIgFvzSC4Na2Tt","st_dist_07":"cC72L8GPxWlnrC58jJjf5Xm5","st_dist_08":"PHzGM6yyaJNGwXDHwxVRVzMM","st_dist_09":"MTDoPeKWXUbpjWt0Qw6hNQCM","st_dist_10":"7JY8jRVJJJDs6PcPJwk0Hq5D","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LnChjzUWHNJvAN4iuyJJMhuPUI8w6iyQQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":243,"st_w_id":1,"st_quantity":70,"st_dist_01":"i75L2MpluqnaWL00Z1rU5284","st_dist_02":"q5rTqEtk5o0Qt0z0y2nZ0hRa","st_dist_03":"gEvjfvKprUnOXO7jX9EzCPaV","st_dist_04":"bYq04Ckq8kdYZ71dNypnDp03","st_dist_05":"zbLu2OeRATidqF2GQVV0uWmw","st_dist_06":"o9sMTbcg3Cv80OWufzlnFpyG","st_dist_07":"JB717XjkVuwL2fy2U87Cowvx","st_dist_08":"ZZ2GLuSvX5xu04phaIsJcpZX","st_dist_09":"gnR9pWV15DwynCPRWlCGSL78","st_dist_10":"AnIqCfpTIaaW6y6Fd8IcJhZ0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nzcgtZiXKhOgICOajEev1SRsDPxQF2cZnGF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":244,"st_w_id":1,"st_quantity":77,"st_dist_01":"JR83wjyUcxCZSlqjncVVPFtx","st_dist_02":"mGzsL6bixaibTiC8rNUZNac2","st_dist_03":"be00jhhyYbsFhFLmohuvh7WV","st_dist_04":"d4hfBKOlyw6VhxXld1OJjHQt","st_dist_05":"D3sxl3yqvRM5GCDZAlyG6y8s","st_dist_06":"AsjZeq8uZTtNFPo0lqJUgk4T","st_dist_07":"NVXcRIJjQRnn66tAPtWsEPbv","st_dist_08":"m32hubGcZYiPWOKLdVSGzBDt","st_dist_09":"v90Ab8R7HyrBDL7HSVnl5MNV","st_dist_10":"09nPyWB3YZFdDshHfUbBmBpk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FEhcrMHsKZ2XSzXWawZm7Ux3yUO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":245,"st_w_id":1,"st_quantity":36,"st_dist_01":"symcTHIstYf6aPugb49bpohx","st_dist_02":"dThNwijIgMllMcelgbTWsFmS","st_dist_03":"bNEps01I2re69e4KwmqxST76","st_dist_04":"KF7r2dwRxfzxQxQudWpD4MXj","st_dist_05":"E8nBFZtyasegi3NnUw3M4r9U","st_dist_06":"h0oNThq1i7yXActTHUGb9ehl","st_dist_07":"WKSYQbJyp9JFlVKrptnljHPM","st_dist_08":"lzEsLvhrlVVsd6lXPwgEkCRY","st_dist_09":"5mC4ZCkBQHY5QB28kb2fpg8b","st_dist_10":"ZUCth0NNHYVoN4ridA6ftDvy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KIvxUhmwENQABA6GXXkeewEsU95G694RuAOQu8u3MCGlkOqL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":246,"st_w_id":1,"st_quantity":70,"st_dist_01":"6UGI14EQZtrGf7NgnMs7UmRL","st_dist_02":"Qis1x7xhakO0ZLDISNJBtEfs","st_dist_03":"uaZxcaRvX39ygGrJ4rWx5BPy","st_dist_04":"kgA8SYXWrgmVuUfOwnlJowW9","st_dist_05":"50eQawlERxeQTNGjw0eii24N","st_dist_06":"Ogua5yWazCTHJit70C6AVLjs","st_dist_07":"zGbEd9MaMCEgqguYZ6uEiGw8","st_dist_08":"9xqjmssqNfWlxjjGI4qlRkYw","st_dist_09":"BI1v21XvaYQnAMoKAqHRGvzr","st_dist_10":"7JWnTzauurgDAK4ocWp83AWp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"saBlvH2nTHVWQJsqVJcR8whGuoUcDG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":247,"st_w_id":1,"st_quantity":68,"st_dist_01":"QXqdyNJSpzsRohT2wmw44B39","st_dist_02":"1xAEujAMcd1Oi4fBzqWyvAst","st_dist_03":"flOwmTl5V5QNTp5JjXu0LL9R","st_dist_04":"gQmyVA0aJbN0muxvdSKvIRaV","st_dist_05":"lQ2XY2g9OjGoREbNwfMVp02G","st_dist_06":"v7lzdi7oh8i3lWzcsXRWxvCV","st_dist_07":"syKTQXGIDnfReCa59jsA86mZ","st_dist_08":"9Jx67JAf08wXsqY3FLCtMlNE","st_dist_09":"dg76lKw9B0MgROKJbC4cniEs","st_dist_10":"0geDFjkpgT7kBds73R8QNnbw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5cc4V9r3HkUM9gALLnIAYLWYD9SkG36vyb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":248,"st_w_id":1,"st_quantity":60,"st_dist_01":"BFjWy0mM9OZNxfVhk7I9fNm2","st_dist_02":"GVyq4gjwLnGyLG01rf6AVelH","st_dist_03":"vf8gVvwqWaPWVBiyyZZjarQo","st_dist_04":"olgUpsFjgxxY7eOyRLRDYfWO","st_dist_05":"qlxTxBzv97m89jRbO57l9stX","st_dist_06":"kg6vHKzy6m6t6OtFZWlqEThZ","st_dist_07":"1FQiUL38krHCQaMEh3LC1Qzn","st_dist_08":"ANk8JgpRo5hnGiCrxjqxSUMK","st_dist_09":"cGTxa9qYonzxpccQeQCH3CUd","st_dist_10":"E9qzZpkOZHifbC3Tgi9QI6Eo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xPpn8IdRedkGWm1t24bgaUII5Xrvnu2l84e19iAz8mbv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":249,"st_w_id":1,"st_quantity":68,"st_dist_01":"UUKJP4GHUgK762K7gbzgC2QL","st_dist_02":"pyBHlxlfOpspQFlXeawoMQRq","st_dist_03":"p21VVoKiIT2siMmYmpjnBThk","st_dist_04":"UnMYPSWw6cy4N2xapccsx98G","st_dist_05":"A7IoiJDFsSd7Gjf3W7zk2EU1","st_dist_06":"8ygQB2qJVp20YX09VRMwdyX5","st_dist_07":"UXmeva6LZf7cxYchyS94E22j","st_dist_08":"gNgAcuFOAKrw5PlclTPJteTL","st_dist_09":"K0ZFhiEcv9RB5INfritpmrWu","st_dist_10":"cSd8w7RjvuEGrRl3PGYdfyBL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2KrYnSsIswnAHhM0OQ3Y3yiJd1nzC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":250,"st_w_id":1,"st_quantity":51,"st_dist_01":"xDh5n6DJsAxPSU5rCoKBTZcH","st_dist_02":"x9rVpQyBuLFaG11LBYtrTLvj","st_dist_03":"UugkQ4YszBCXLzdhJrXL8Hdd","st_dist_04":"y6ynB11zJYIVwCWY9fI801fX","st_dist_05":"qeCOWcW2KhstyyTWuFAVoGdO","st_dist_06":"vIqkTEaPIdWgshT9tnzjqFDJ","st_dist_07":"uaP5noc6izzwYGVwvWq9CAP3","st_dist_08":"suQitHzUy748hHxUMRxTEskR","st_dist_09":"LTjhGeekPqOq3tqyYZSXlujP","st_dist_10":"lRHTSMTUDxo1jY2e7oBLrBRt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jJ9GmnqXBch9xLTmQBh4NYwjBU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":251,"st_w_id":1,"st_quantity":12,"st_dist_01":"PFDQX1UQTl2TENYh0UVNMvEp","st_dist_02":"ouDd0hVNlUBDPMjA72BCuy5v","st_dist_03":"uAfTBTXXU4xdOdoLrQANFnmq","st_dist_04":"l3pusKk9P00SwBWRjH8E1ZQi","st_dist_05":"GCVtPYxxU7MTz4XZAGsogqHg","st_dist_06":"JmM0QGkuVIplCICE8kWkOv0G","st_dist_07":"QDUzm0dSR48y8ldfhKtOPoV9","st_dist_08":"JOtVR7mUIc4O80Nji1CNcE12","st_dist_09":"2jW523eSM5OlwoYGg7SuAbo9","st_dist_10":"FmHtXAlZaFSWcC1JMXPAstoR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fwZFMmRLStE59wsoxd0RJWHcvGv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":252,"st_w_id":1,"st_quantity":75,"st_dist_01":"r6ucubnfOSfhkT0X1GDYMJ3x","st_dist_02":"EQOtZm8fx3YmiKQiv2DjkpSQ","st_dist_03":"KcslCCqb74hm96YmJNZZEbj7","st_dist_04":"zeb86gDG6ls9H4pXCw0GVM42","st_dist_05":"wktHaDUQp1ruNbi17MjWdASQ","st_dist_06":"DoxfOxH7i9pXV0Ne6kxunfTC","st_dist_07":"Con5O9vI7qGKDW400jtltqOo","st_dist_08":"9J1B5cr0tiQzMEn1fhfojgl6","st_dist_09":"leKJvbpdbGXCvdl5iU7A5QtV","st_dist_10":"ZTXWxjuWCY2u9jZpzrgHjViv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xuc1nDX5K58ervyquzsRa3CdPO7uagfn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":253,"st_w_id":1,"st_quantity":80,"st_dist_01":"4PcWqTWwqlM2xGA2H5Mep8gX","st_dist_02":"rIKdQF0NTnu0zd8FHYzTt26d","st_dist_03":"9JX4CBbVRVSFsiBsR3ZYy5Np","st_dist_04":"dNCLU1cj0xmlb8FTMyTGP6Ll","st_dist_05":"FXXCuYNNGLUSSXhhhg8OsKf8","st_dist_06":"i9tuZPpNHGWOnzVXKXuI8YnG","st_dist_07":"S9AEIqDzq4wu4d3Q4SEH0Rf6","st_dist_08":"uMEl6GLFxfFxsI6mdhW2YFih","st_dist_09":"g3hpm9ZTuwqBkP4Zi62NvN8W","st_dist_10":"kmFpPGRQYTXHrKCBgOEKYuAC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XrwrPOGW4LwlDU8U744Tx8N49b8cVEJBFhVh5uU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":254,"st_w_id":1,"st_quantity":70,"st_dist_01":"rKsDzjSnuSolnZ5GEVhckd0A","st_dist_02":"NNVi7FNpQzqZfk1gv5AEhype","st_dist_03":"M9ppIQqZMZnRYfK5ClfTu8ej","st_dist_04":"wQxc5vzCEefK7zufzd9ZdFPW","st_dist_05":"QUEDSf2CamsS0lsO0zTsQd6V","st_dist_06":"swY6tHWFmBMydKZAbvg4Zjdw","st_dist_07":"QFqYD5fKv677FPWYxEDRMjpQ","st_dist_08":"JtMLyy8HZzLtV2uNqLyf0kUF","st_dist_09":"BKcHrpivuGyJp3r2XwwsjW5H","st_dist_10":"ukNgnxnWC8sbceVfGybT7Ddc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VPil1JcIR08zpRjKqWuk8nY0MNWaehZqxngRGrtX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":255,"st_w_id":1,"st_quantity":35,"st_dist_01":"MMZicfRnxiHGVYy1Avjn1vQy","st_dist_02":"AK3yuetgBxXlBDkSmSLaxgWl","st_dist_03":"6hOgXFWb8i8ZXoJoEYMqqEsb","st_dist_04":"6ruZ45XGPgzB08K37mNzg0Vq","st_dist_05":"Fugq1T9MvonyvLrmHqi3i6tz","st_dist_06":"C646grJdYpw2NXnn9dwFzZSh","st_dist_07":"bfei03tARJfu9yjGXesHuzOK","st_dist_08":"aaWnqfMKx91YnTF2ceLqbvr9","st_dist_09":"Jtk3N771IPh0p0beMB4b5Gln","st_dist_10":"Q0SMK3UG6xhUQx9fk6KkQFId","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rsWn4yC4FSySar2gWOIakn59jHioAQgsK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":256,"st_w_id":1,"st_quantity":40,"st_dist_01":"xTwbjWnPBUJN5b0WDlEeiVkA","st_dist_02":"9NXyZnh2aEMxzhb6DLhIzPq0","st_dist_03":"tAgFBDgIE7G2NZIB8XNnXWWw","st_dist_04":"NqgqEGwKYpNQBec1nX10Yf8f","st_dist_05":"Q3fjbO8daO9aWYArLgJp5rMV","st_dist_06":"NzYZJD62ZxLKLbPQKAt3cMIT","st_dist_07":"oevDvo60kr3NI97EQsDXeig0","st_dist_08":"T5mSHlIJywemS7QTNQSRZrH3","st_dist_09":"BeZXtHQknWUVCjPS2D0mu0Tr","st_dist_10":"JuPQldxQnkAWxI9h0DRREb7p","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DZbW83UqMTStkfWjzJPtnp1VmgUsVWMCjdkMp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":257,"st_w_id":1,"st_quantity":95,"st_dist_01":"8vv5NXxOp0To8zJ2yIzcrTJA","st_dist_02":"0NO9lLYqOvLuhxcstaQcLVPs","st_dist_03":"zwTErMOe6FweARkuEAnebZgz","st_dist_04":"8YVS4TORagz5dpZgAEl9NNus","st_dist_05":"JOtAbQv47om2cAFX1xgYbxKS","st_dist_06":"489r28CkFtlRQCPvCDbaOm3u","st_dist_07":"eEr2YJny5BAvxAnTGk83jvOR","st_dist_08":"uFIY3esaplik2KV3yc7Bmzu4","st_dist_09":"jBwlaHplSNJ3GLFbl9UyKCYX","st_dist_10":"Kg2HbbkXnhEaKOpE2TZuCvu7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"z7kB0pn9cL6KZMPexZlkxJMA0uSa3Egkzl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":258,"st_w_id":1,"st_quantity":19,"st_dist_01":"Bu7FRMI5rEb0zAodjI6zOx6B","st_dist_02":"vjM6HpmL62uBqycQNiSeHGLM","st_dist_03":"x3wrgD0Eg7HgKgI2He5GRe3r","st_dist_04":"rhcQtGbIC8aX23TaLtlkKkC5","st_dist_05":"wOhWgwxW4HL9k1bHSatM8cyr","st_dist_06":"IAyBsMAsx49XRoEdzEphfB0n","st_dist_07":"CGLHUyaPR0hHYbzkKqbpBFe3","st_dist_08":"VuB0pL6kI8NGbDcL4RsMB4rb","st_dist_09":"ZMwnkP5j6NCTpS9hy7sehY3b","st_dist_10":"mHfrpuiVxbtxOE0vUcEgv362","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v53yRlx6B8ncOlc9DNhPg92f2nK3ry2PhtSm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":259,"st_w_id":1,"st_quantity":58,"st_dist_01":"vBhxwQrapx1izs9317Eg6G35","st_dist_02":"bUMJICF7KguLonHnPR4R62wv","st_dist_03":"egwowTlG7QUeAVKTvGZUb28l","st_dist_04":"GPWc87rA7KrrFpr2QQwx6chl","st_dist_05":"oXvEt04OSkgpLK5WWXPKIU9h","st_dist_06":"nqrcR9KxSRJBbihHaySh3Txq","st_dist_07":"2CWpws0nwo9GncLnlsRGndU1","st_dist_08":"8ZS6M7fh59MZbQooNxvMOcM0","st_dist_09":"Wt1d8RNys2ZIh6xWPuecZcRI","st_dist_10":"NrrN2J46EynXiGZBZ2jqb8H9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6lmJIgskqP08fN49dbB7DuaqWYAfAjC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":260,"st_w_id":1,"st_quantity":50,"st_dist_01":"xVljyJXbgtrDIeOtAFRkcuh7","st_dist_02":"ybiqcroUveqEezdXkHvTr5uT","st_dist_03":"6dfd845bLqhBhuAtfeWl8OFL","st_dist_04":"S169TY2orI7UzCmTQj2UOQqP","st_dist_05":"axHU1ISoFggrotDeYriyMYHE","st_dist_06":"w5SoFD2Wjc7jIU6YKzKtiWiG","st_dist_07":"avocLywP2OZOWerXpOCMxwoQ","st_dist_08":"VKXOg5EwcWsKXRWnWZeOFKMc","st_dist_09":"cZKP7j1oiyWJQwFbHd4lsgGk","st_dist_10":"Rq3gs6BqSKIxyd1B06hlkwP6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OLYcHAk5yEMKjfoyw7jezRRYeoaZpppGSK7xi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":261,"st_w_id":1,"st_quantity":97,"st_dist_01":"pt6GFJPuoiFtWBIDA8St7BPu","st_dist_02":"FlL9Qxzo9kofVTHm1BmYx6kI","st_dist_03":"KXow60UxF8VTETrVToxInIp2","st_dist_04":"me71xNnC6WosSxBuKyVHapvC","st_dist_05":"GkLulREqFLYExiNjLyxrxAa5","st_dist_06":"QJySDZRCUiOx29rVmZFIhwaG","st_dist_07":"e9cgBaJEZsYrMFuNbx5GJNCS","st_dist_08":"kFrO62wiKZX6SaSk18Lq2Kkh","st_dist_09":"mYJeeCCPoJID9aTrG1m9CqYU","st_dist_10":"Hcal67fm0YL3P3pjlNDIoGFr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1YyBEDgf8Aw4Aw5bybeZ8skjFDMtJnfrpXCxlbq7GGUhQf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":262,"st_w_id":1,"st_quantity":100,"st_dist_01":"ejl5rW99JZZhyh2VpdeseNue","st_dist_02":"hsT9X0g7sKtFGt00EB8P6fq0","st_dist_03":"xFba0PwTqFYNRl3Cy0mIdrRt","st_dist_04":"6Ujpz0fDxIP2Y0M5wUMXDoih","st_dist_05":"HJOnMc2cM0nMEc0sfHjbtrZT","st_dist_06":"Jkn6q91dhLLLKtMMIc808CJ7","st_dist_07":"KGgcwHoqmkfW3CpMCKuPzrKJ","st_dist_08":"b1gWVr2Vyb0er54zRZNP4Vvx","st_dist_09":"6Kw9f91WHGbcysC0ejgNNf7K","st_dist_10":"5KERCiIIO1NDgXAw2ux2OTYx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TWEkvhoTYqf0dGIu8nKNcisIXaE0sfH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":263,"st_w_id":1,"st_quantity":85,"st_dist_01":"leIVean7P7WJJ5lsOXW29dz0","st_dist_02":"GPPXiTIiVz6ZD6LjfcogakSO","st_dist_03":"HciAxCZUw2yNFRQnME9fI3si","st_dist_04":"1aj9A6acmI5pyztoXmoYKZAw","st_dist_05":"9QN3Ag7c9cjgQxMocVuNNlOi","st_dist_06":"3SEfKGMTO8IDmUHKqz4H4vLX","st_dist_07":"tsvGpxz968jBtjfR9WTgtU3q","st_dist_08":"hTWAMahfFmQa2yTlNQpFzGTV","st_dist_09":"zYemafNDcYrj81UNp7jhma1L","st_dist_10":"WfiNbKfs41IC1yr90JTSabgd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tyBIZUR17VomtKRhNrkHTmroriginalWhwladCnErA2VN8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":264,"st_w_id":1,"st_quantity":97,"st_dist_01":"GU6A1QA0qYdzK4OyRmE9eicZ","st_dist_02":"zfEHaXoxJPwEabE23AFrhUFl","st_dist_03":"e4Y2bV973vMHRQWHfJCQRdDO","st_dist_04":"neq0m2U2j8g7CNL8kQ0ngaOE","st_dist_05":"RfFs8qThtaxPFkB4InIsju0r","st_dist_06":"fzJ7nZS4pzvnREH2xwWi73mW","st_dist_07":"YpL1x1z7nVDH12eX8OWmbl8n","st_dist_08":"s7sTHssdgTuHx3yaMqA6BDsJ","st_dist_09":"SseRsDHb50EbZl0K8DXGdIhT","st_dist_10":"JwvxH02lmChi7UnZBca99n2c","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AnJS7DCdR2drPaTgzvpgzCGngP6Djuhn08HSbY54nW0HYtLOF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":265,"st_w_id":1,"st_quantity":39,"st_dist_01":"b57Htz41o4fvQkyrxvpMs7HL","st_dist_02":"GJGsjlgEejOoKOSG92YfyYRt","st_dist_03":"rQAXi1jzLjaChXfPsl0RlfAh","st_dist_04":"WABSbnktpyxOqc5Uyve6jFRS","st_dist_05":"eSSmuusscaRvBjNZ4WjJcAb0","st_dist_06":"w9tVJpobB6JUOLrIYeuKOODh","st_dist_07":"yBNHHovRRaIPjmzK62REnhTa","st_dist_08":"tQZYzodrZJtnbItp3waSQTLG","st_dist_09":"aDZUOuxfrKophfDygJSqVq0w","st_dist_10":"LLN9ZqwqIDxIgUsYCd8DMA8I","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QSR2ncGNa27ryVzEUMShByt09J8Y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":266,"st_w_id":1,"st_quantity":87,"st_dist_01":"GM3lAbdH7m8wCATcNr4RCf64","st_dist_02":"bqLYQnfP1hR1OXnlBTbHvD3F","st_dist_03":"gc6Flk21Kg7IqtZbWRO1taYv","st_dist_04":"PnX9QLWAteI3t5ESAWCHkNrb","st_dist_05":"IrZrjbmHUK7ynAkrG9BdVnyj","st_dist_06":"fptLfqKR9wwubdnFWz3qP7pl","st_dist_07":"dLmW1Igp6USTP44lGVoVcrq8","st_dist_08":"LteDhbRdDTy9e0svV3l1fpxh","st_dist_09":"GZ1PnGwdB9Fsul3oKQ1GZKjW","st_dist_10":"EmvP7TGI2PO2HgbuB6gEYppZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"REixsMT1dEuXWojBnWCrUoqxUd4xldwhgqK96D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":267,"st_w_id":1,"st_quantity":57,"st_dist_01":"axWxKYL2A7timRQNId1krp0B","st_dist_02":"EhxUFEewD3dRHZ7tAXBM5VCT","st_dist_03":"QPuCn5K3kmCMLdYhQzrmUBsB","st_dist_04":"5zoY67e9Z0X8ixYLT3y0RERz","st_dist_05":"INSzWcFoKMtuwRXIltoMT2BW","st_dist_06":"Nnrnrjp4u7NdHJv2BW2kQRtr","st_dist_07":"D484CmcpTgoGqs5Cmd4g4M14","st_dist_08":"jhbVv1QTfZRzyh4QwmCkX7nc","st_dist_09":"yS6YQKSvLX0R4kDQDdrlnDYT","st_dist_10":"D6q4AR4s7HaEZJ8CVWCT03ie","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v1WTUS0q2fYzO92pKDcrW8TR1QrtWQd0Ez2alG2jGtoJJqtOlm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":268,"st_w_id":1,"st_quantity":68,"st_dist_01":"BqPkAIkFw6YPTMDKDwFCFyn9","st_dist_02":"qLVnPECcKoXn1pF5chOJ50iE","st_dist_03":"ce4kIUWUzd0RiadvMM7SqycU","st_dist_04":"bVCGIjI3NHyxlbUzB7Y0A4RY","st_dist_05":"xNKT4xJ2xHM7WKuFTOeR25Tp","st_dist_06":"i2VVAY1mvckqaNvsObOhZtcf","st_dist_07":"klFF9Lj8TA78A1LcwHfpR7To","st_dist_08":"aBlI28cL9GUs6dJr0VkqnOP0","st_dist_09":"ixDQC2Re4XxEf1sSUMKiQ3ed","st_dist_10":"L2HO5XQbjjik8TuDtxe0sWW7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NdZjlIMY0tmMsIzKVREY244WqKyEhEZfep2bLfunhP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":269,"st_w_id":1,"st_quantity":48,"st_dist_01":"JMOWOv8mKWIYFy3LXXJFFicC","st_dist_02":"EnAGtX0T11f9wwt91UlhnSBv","st_dist_03":"EyZLvmDl3QVwwrKeAmcggBRS","st_dist_04":"7TGpQNsHoh8LJR5r7eZ6XjQ3","st_dist_05":"IDXbPXZjtNOmfLzk1Tn2g9cf","st_dist_06":"MyFve0VuxNN4IpZzSVKqOUPH","st_dist_07":"a9y3sdUUQAhGCDhMCwfqqZqO","st_dist_08":"zTs9f3igWI0lNa1ouKEGhx9W","st_dist_09":"Q9KBAQGKzecc248HmJbiBjaV","st_dist_10":"rDZPMorfJXEfWpu5zAlEKFTB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Xg7D7I3n5YtmnrxctMBA71bUX1GwG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":270,"st_w_id":1,"st_quantity":43,"st_dist_01":"YFAIJ8AgfcXyxr0DBUXaqKf0","st_dist_02":"LjCMvHa3w2ddseGxCGsta01s","st_dist_03":"6oAnC9CD546RNrE64s6yLw6A","st_dist_04":"qJGzDpXJSEsbgqMlVJrjD9Kx","st_dist_05":"ZJluj4nSxhQRWzAVQ2s7iOut","st_dist_06":"yBrnIP4pP8IBtQrYwdtknvLq","st_dist_07":"ViUPeJxq7IghjWiVO8lGBAG3","st_dist_08":"7thSy4iiMvkFIgNbY4XQ2sLl","st_dist_09":"zTaay27KNApwUhqUCKiTAy8g","st_dist_10":"ExWgyqj64yDBdF0rhedCDNLm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DSwP8UF7ds4vv1YV4v7AiwiqTONHv8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":271,"st_w_id":1,"st_quantity":92,"st_dist_01":"L6b8UVfPgTi4zB1K2DUNhduE","st_dist_02":"wVPIWFAIXKZwihQ4Q1X6u7G4","st_dist_03":"knAs7NUzXvG9hiv2MPxQCdld","st_dist_04":"C6Xs9Cl9lJYfv2aCbJsMwdo2","st_dist_05":"XCWWrH8gmkeWFm0j0cm38ars","st_dist_06":"v9M8XYJT8AUPTyEsET0eKCbs","st_dist_07":"KV77QWqc6TXAoIEpGdZivMqg","st_dist_08":"TpwUrCzXzdLcx9Uo4Zx06QuS","st_dist_09":"wY7PAXPYVcI69CJIKwDUXtP7","st_dist_10":"Xh6zhkOQsMaZ9KCQeerrQbI5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Wyabn26Wxn4l5643FmQK5qMuuun"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":272,"st_w_id":1,"st_quantity":32,"st_dist_01":"hN9FMH7lbzWudqY544oJg7tj","st_dist_02":"jSd1b9fLErScmnBNRpocDeBx","st_dist_03":"kCnDpZ1CFnUryrnOfviK09Im","st_dist_04":"HYdYF3LUionAx6LZotIec7CF","st_dist_05":"Zz0CTPZsbeNpayU844AZreWx","st_dist_06":"jBT4SfcA6iFmokg1AtsfUg98","st_dist_07":"ftykJ7SdFNuoF7ow9Brx181X","st_dist_08":"PaiLs3rkPmOW02lwuAiQXaCR","st_dist_09":"VQC96cCLQMCVpVcnraSeSwC1","st_dist_10":"DHtj8bLNS18tuuCNd9b7I54R","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2bUI4shpG5TGLcOAJQbJX36jnrQlG6BSMPwlq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":273,"st_w_id":1,"st_quantity":67,"st_dist_01":"hFZkGeeQBaFl6OHMX83pwGQD","st_dist_02":"D3lqcL9PhgWTL50dyDlEqpmo","st_dist_03":"FJUrdSqD4MOrz7TWIhNyWkQz","st_dist_04":"1d1q2yPhc8eNCpStThZEp6Nr","st_dist_05":"yIdgrnkvLuBnlQN3EeWExrV1","st_dist_06":"BZAPXLkIuRQlZtckcAndh1Ki","st_dist_07":"jJA5b6y8Bjg9lZdlbCkGfgoB","st_dist_08":"vR6pHFLb9aY0NymCqdmz8SwV","st_dist_09":"Qp4D0KBAtyR7sGMGFVrWcdxN","st_dist_10":"cVYfVfZsnoFJ7eysM0ChQGI4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XEdOurbIFyy0vWnwhO6l5acamZhYxazaS1NoIxcR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":274,"st_w_id":1,"st_quantity":57,"st_dist_01":"ESbfiHjcoo3s81XunKrkeCxk","st_dist_02":"IO5Wipp6xwFPC0gKkM6uq3se","st_dist_03":"zLquoHqeUctAlpNA036sh9NA","st_dist_04":"Oi6gQW1fQfUDJ2SkrCKXowtE","st_dist_05":"FYt3fJQ2GXDKWN8Hgf7fE2Kn","st_dist_06":"4T6nJvqTZ9U69JOq8wsAe5Ue","st_dist_07":"Mw0DU2LkO0nV0KIqaWrOiGzY","st_dist_08":"UH1rcpMYuK4ustAPBP82Y84Z","st_dist_09":"oAL0DxLVr2QPzQIGIL93SuRI","st_dist_10":"xx12HiVHc0W7x51EDWwdA6o6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RvJlQwhro6qpYEqOIFy3hHuaGhHr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":275,"st_w_id":1,"st_quantity":100,"st_dist_01":"APKlfBtfgqSzoNgNj6RnavCh","st_dist_02":"X3xtEbeuYP7BIX9RRCmnG0UG","st_dist_03":"kZJ7qzFFtP7FvzfPJjh2X5iX","st_dist_04":"hLGvwttiTY0IZRukjqqfdHtW","st_dist_05":"oFXtzll3eJEz77TUOZyZG9ew","st_dist_06":"tx24eTxX6TzmH5qR4BJKddaf","st_dist_07":"OG5wxVVD1X3Ny8mrbxSqkZpf","st_dist_08":"FqruLXFzfN7lVRRLLc8mXujw","st_dist_09":"t7JdJTV1ZRQUxS4LrHq8CdLY","st_dist_10":"R3mRKRA9a1sa0Wwp7krxfPVH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Vikkp0ybbUnTlPlP6KPweWCmTkM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":276,"st_w_id":1,"st_quantity":96,"st_dist_01":"pnNDckFDuxUDaFkXy1MPnSWK","st_dist_02":"pJMom98Ojayiilqlxq614rQ4","st_dist_03":"H3FUXj5xXiRjU5Zxtch33CvI","st_dist_04":"J8Um9gZo9Gjj2kvRoh8E9xrx","st_dist_05":"6gpYyNSdAKq0jW8nw6swjQJg","st_dist_06":"t1Gx3N1ugtphijUeVEKoaSQJ","st_dist_07":"EEob9XobJhn6iEpACrW8N1sY","st_dist_08":"EFCl7z3ekuAoKbgpgOdxQJKP","st_dist_09":"IHkPLehqf3mXbmxNVaTaL0xN","st_dist_10":"O9RwmRue8qehHl6iUiYgGMTn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oG8eHJfPmedeDK2BStyZFGZlz7L5f8aBsX7ZyZf9vm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":277,"st_w_id":1,"st_quantity":99,"st_dist_01":"5J5yDN59ubFlAC7YHAMYuJek","st_dist_02":"xSYRK2lPCOdRwcXqoLJqHeWF","st_dist_03":"3obsTefBRkJ4OTD3dvX0Ibe0","st_dist_04":"MiZW71zszwQAFlNGZdKLDIJY","st_dist_05":"F8rk08THIiAWlZs3eSxnuNwt","st_dist_06":"Ovee3UsT093IJYnyE6xGtLfU","st_dist_07":"9IwCg4gOvH6aPOPf5ZT9gqa5","st_dist_08":"GB5BmWyhJajaze3ld4htUcel","st_dist_09":"aW6VohLiVujA43VBTbnvCTvu","st_dist_10":"eFDHSNP250PzdSoi5xkJhFe0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BjB05reP6WFSMOuv44SDx8hwTBcnSnf8zr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":278,"st_w_id":1,"st_quantity":51,"st_dist_01":"ZZUvXdlOl3ohFbvk6I9fEPDW","st_dist_02":"4zHfKSJQ5UmIFBNmfETVsvLn","st_dist_03":"silnJsn1U9MFQ4AZBB0luY0t","st_dist_04":"LhSGfU9hxKaddzcjftt7OL0m","st_dist_05":"p4k92DmCGmbZvUVldDzmqXKh","st_dist_06":"OdIrvisvbOEHGOiC06DxvwQt","st_dist_07":"piMT4Idjgtt3MHUU5mCD92uz","st_dist_08":"S09n4YZY5i3vvm8gSDt0JtiA","st_dist_09":"OcAlU41E8Zccmtl5fKxcgCQw","st_dist_10":"qahIZQaxxN18gfyehf0MfoA1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"J5G8XHUW7INtzdhqu4xZnsTPn6fYmfSSNpMghxuYgP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":279,"st_w_id":1,"st_quantity":33,"st_dist_01":"5U2hsnEs7wgY0Y3NCD2L0Xsx","st_dist_02":"3neK9hOL7xfszyFZpNCZUHF5","st_dist_03":"Unjvn4fEPFObmqF08bIBgRid","st_dist_04":"tD37QOroPT0gnIYhAvQQUVzn","st_dist_05":"yzqLKzWWKxla0kFrpMWHbChE","st_dist_06":"Obf9UbropGxgWtMoNZcsDtB0","st_dist_07":"fvyWVKCxhw7T826GuhLqWpZp","st_dist_08":"EkM25xbNc1KumOaUzqjuWNry","st_dist_09":"rMZclDfg3fCXIfbVCtNyqS79","st_dist_10":"JOXrJkJJWJOJefo23IqrDqZh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"d8lFuInzVPuowzjsbdh4AQ4d2LZNwG14hZs196yFoL9L9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":280,"st_w_id":1,"st_quantity":27,"st_dist_01":"Oh3MgGTVWWlT076EnKrSQha2","st_dist_02":"PTbhN7XvJRCpUjXHcgXoBTs6","st_dist_03":"9U4DIC5pAsiMfmNz2YP9CXRZ","st_dist_04":"O9FzkJStIl6bHrfcfFcs4El8","st_dist_05":"azVQ39zqzZTOgFgMF1Qcfofo","st_dist_06":"bB3OHIRxcUe55NzL7MaspeZe","st_dist_07":"PYVeKq7rJVzrakQ8ePErTVKP","st_dist_08":"enk8HripQU8kyH8qtKXdXvf5","st_dist_09":"QJrDevk806GWLtU3hNdsq8UG","st_dist_10":"T1HvLHJORMC3uM4Xw7xArAz7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"u2nOw79FM4PnoKBMNR9EbRey3d6XZrQe0Shcw1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":281,"st_w_id":1,"st_quantity":65,"st_dist_01":"mfBFWknPm45oCDvkmdXSSx4N","st_dist_02":"NX4TCTaXefqBjwF83BxC83U6","st_dist_03":"p7ghaMXtDflFUeU4ouupOI37","st_dist_04":"HMjGxgpZ4FBDYM27Ck7506jk","st_dist_05":"xh8CJnj4POihGCEVgoUgKUsp","st_dist_06":"V3vwnnxyxfgGmFDUOzZNRAIh","st_dist_07":"L9svTLUAFLUVuxMjWuXmdpNF","st_dist_08":"amlFWxhi3ak6Pr6M8nnEGHQF","st_dist_09":"H40ldpT2c9vdaVzbJdsCB7lO","st_dist_10":"Gwah5Efdw222Oo039g2YJe7w","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"P6Sd7Kbi0A8SEdqU5sFsqLq0LjZEzRdHZs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":282,"st_w_id":1,"st_quantity":29,"st_dist_01":"94PELTjBtEmkUh1w1d809L9h","st_dist_02":"KMRLbAOJiUVxMuxoZARjoow8","st_dist_03":"xzkZNdnMgykbNAkyiQGWG3KT","st_dist_04":"fuXnLqIcF6akUdDpMeQEPxe4","st_dist_05":"FtY9O28P14TnHdpPho91zfvu","st_dist_06":"Am3psTdT7nPNtwkI7lCvks1s","st_dist_07":"t8oE3gJAKxG1h4hFpsHFc1OO","st_dist_08":"Pz2LuuiDPNIZeYBiWK7amhwk","st_dist_09":"KnyT5KLUJHHkvwORmOFS6guu","st_dist_10":"P6xzrelgy1dUVvslYF2eHv0Q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nWdLXvu4svli5jVFBExevvnSnO7rrpoM6ne95rz2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":283,"st_w_id":1,"st_quantity":99,"st_dist_01":"XeHcRfZwq4xVOgOu5kvhMWU5","st_dist_02":"kIlvQNpaRoGfd5QfchUqdHVr","st_dist_03":"Mtcze57bEozg37SZwafky6wK","st_dist_04":"kKx7IlcDFUd4UyIoAVxM7rPN","st_dist_05":"lKFS4B9YbZXFqd4iMTBnGa0d","st_dist_06":"eBU0NnlTPrtTasiXYQW9XtJs","st_dist_07":"dfUbDVyIbyCVqbMNvRpCjHKl","st_dist_08":"MW6V2R7EjZE9RG92DEBnHADR","st_dist_09":"n6Yzde6fubPSAAdv712qODo2","st_dist_10":"3Ghx12unhug4zTEZQ9EhTlco","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5ink6jcEgcs95nqLwzT9IU1mlGyR8EQEXPn6Q0wrC3WsL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":284,"st_w_id":1,"st_quantity":72,"st_dist_01":"m4r1bWuOxLarDJA54XdU7ms7","st_dist_02":"IDWUDUPgSNKkWb480MWH17GM","st_dist_03":"ZlCAgmPHQCz6Mgb6d7qW1Icp","st_dist_04":"jinhV4d3ZOUVlbtk9PtiDmnw","st_dist_05":"J7JsNzQyPjRoJkwPy56Th0b6","st_dist_06":"TKVFQ3FHr5vktgM8FV9VHcND","st_dist_07":"GdbsE7gF8Xtcc0JuxXAudA7V","st_dist_08":"ELTNtE6RfSa1FUbReqGc8uiM","st_dist_09":"iKNvzEle8c8LEY7GSsrK6KM7","st_dist_10":"VM4knwRXRBt7PbuOJtPhM3ek","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YDsBNVGlIsk2N4Ds30k5nGdEg8LtUq5ghQBXRnuH1Pqu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":285,"st_w_id":1,"st_quantity":100,"st_dist_01":"mXeiS5bglF2HKmtyGRkaoavM","st_dist_02":"4B0RhgjL0QRKQRfgQr6mGTfy","st_dist_03":"GkTX8gFLqhnsDtEE8eCZ1dIh","st_dist_04":"T0FizmpQxXyJPtpX6fjGQQdX","st_dist_05":"5KcFTjMGiQgO6nnJQK0OW8OQ","st_dist_06":"RvVqh8XESO00jQbjc1dzfCZ5","st_dist_07":"o1jGTVKmo2PjbMwg0HhpqwuS","st_dist_08":"v5GoGouUNh3xxma3BlpARMjW","st_dist_09":"XN9YA1bdGxdNpTN1ZX4PrTSq","st_dist_10":"s5QYtEtrMRCenRklpTtL7PXV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XI7bCFAcO8WHK1RN7RHlKCQWN0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":286,"st_w_id":1,"st_quantity":74,"st_dist_01":"KCjBvPoU17MDaAdiy2utalM1","st_dist_02":"OsqnOsnnEwO39kLLauz14Oge","st_dist_03":"aqYUS5NN4Y0oAa4lNIfWPDzl","st_dist_04":"bGA6B5l5lgOAafpSfzdb11aE","st_dist_05":"QK9wWwvBS2rmAqAV6TENue0g","st_dist_06":"eS8HIYFtzjceAHpf2393rvS0","st_dist_07":"6aY1VibZ2pngRsjUkE7sM35E","st_dist_08":"yhlUJAA9nEQpRbu8ov0psHIF","st_dist_09":"YjcRiQ4IY4IGeOnWUNsBy9rI","st_dist_10":"CceqN1QbMHP3hM1QaeJw3x0D","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"l99QhqQ6Y5JZjYUU8ErXHMNlB3e1JeMlEIIO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":287,"st_w_id":1,"st_quantity":71,"st_dist_01":"8Su4H5Fxl1TqYVCxyu4gb9lU","st_dist_02":"madF4kpu0PA3kAi8YpCjwrAM","st_dist_03":"FAvoGQzzyQtJ7ALtbuWY53Wl","st_dist_04":"2DpLRHXi1vFLChpCSQQ3igKx","st_dist_05":"y0JIal0iMIQ8fJqtWoc4YUia","st_dist_06":"Gt261FDv43oIVZPLLIvNsh4M","st_dist_07":"5aC2iUekHmv6h9B2v7omnAGA","st_dist_08":"3ZTZBv8KygHL4QugIOIJJlh9","st_dist_09":"ybaLveXvTaJB7H6zRgCz73NW","st_dist_10":"ceDpZxiicwxO74oW2mNgbx1C","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5LAFnJcTaV7Rr29CfAXECi2Wj9m5AlTfCA8MAwpO10oMQZz5B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":288,"st_w_id":1,"st_quantity":95,"st_dist_01":"C55R43bYGhufkWr6NtzlSMwj","st_dist_02":"9aa3bAiIStEG95DaffjsM7Pw","st_dist_03":"fasCZRZHROdtm4bn4HpTUPei","st_dist_04":"WDjrrYkYX3QVG7eMS0xvnGDQ","st_dist_05":"3AL4pPwc9qXrBwbVMB1UB2GP","st_dist_06":"qNceKPuqrCkeuk7OP9mwGSrj","st_dist_07":"KF6cwWN3REXdwJ1XXWcx9cyk","st_dist_08":"POx8j3etiAmFJlqhCv7lHczz","st_dist_09":"avUQr0mK5vBVrMYm4Hll9GgE","st_dist_10":"l9sQlTIzpMvR4seuw3My8h7c","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sYq2addLXjyIkA0OhfRHmUxH8YZ9m4MzrkyD5wvaCTR04Aw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":289,"st_w_id":1,"st_quantity":50,"st_dist_01":"mymtt9lwqN9mkdfDOlg6Jsff","st_dist_02":"SV0VyzJ6QfFHc2QQTkKxSUeh","st_dist_03":"ucoWZMtDZHX6OmBbWXlnchUp","st_dist_04":"yIWQ3YGSuFteimc9cHp9P9Oc","st_dist_05":"qrvnsPGfP7xbp5xxyIPg6nxA","st_dist_06":"F26F4c9h0j4ZUxdSEBe3nUSq","st_dist_07":"H4GjNzdt3I8TlP3smWFRdP4X","st_dist_08":"jX1dB4rdymiUQ4Hgnfn2miTE","st_dist_09":"r9v9eLxIg5Uq1Ue9lDM5YaQJ","st_dist_10":"hoSB24xqPsfgoAUqmIXaWrW3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CNUFoekozuJqcA7WM1CagbNZfd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":290,"st_w_id":1,"st_quantity":84,"st_dist_01":"BEMfFDiM72dqoqjqg4mKvujG","st_dist_02":"2MwGYlYUsZ8Jl62ho7YfHWru","st_dist_03":"IiLlapN1UrXCmwSru2PFv7xc","st_dist_04":"Rf6wB88gNAkTodExOvvlnxli","st_dist_05":"5xJ4cGdyuTSV2GwGeBQeW5s8","st_dist_06":"laxcsQrGUKgoHw8pV8gJQLtM","st_dist_07":"JWemVJELOxtNV0alNe5qMJ20","st_dist_08":"NuflHgzwqkCFKYW8qPEYYo2B","st_dist_09":"kUuWJdNb4UPDA963UhaqdPFv","st_dist_10":"IDKZlS0FHDMF6E8vZP7MH2EK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IFC6AKo5yd62HpNc7AMhrMLA2V5fekOszJWtWqWKMaO7FSjO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":291,"st_w_id":1,"st_quantity":16,"st_dist_01":"0kDnw5DUbFHzxApB1JsAUCck","st_dist_02":"Klr6pDeHQxnsJkFn6khD6ueH","st_dist_03":"AxHqQXselDUBYvV4ae6eQaYE","st_dist_04":"2rdIh9lKUMIzROFb41WnNXw4","st_dist_05":"0tgJ0Y8vKWOw8ZyDMRi6hHy9","st_dist_06":"5Dd9u2YFwOoaMujl3NUyNcYv","st_dist_07":"4YZI9ZnNcXndOizQMB9iQXuc","st_dist_08":"IQJOUYKtGzaFSEC7no3wLx7y","st_dist_09":"Uz8PCzcbaQ3QTOiECtgbqfel","st_dist_10":"6yocmajglQ5L0KqW0pch6MEP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pPqzDtNAdTAdgeQZbsAtJ36eFxyNCCGLSlb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":292,"st_w_id":1,"st_quantity":44,"st_dist_01":"QI6BfXG9BHfZqMxf20XAAmfB","st_dist_02":"wG1duddddMFGNZTfzFI5h7Jt","st_dist_03":"5HGd0CC1X3MxCU3dKQOvk1BN","st_dist_04":"vPBk3HrxYSJ2rq3T6OxoRTtZ","st_dist_05":"0tbeMoy1lcS8cE5BNDrWJvXI","st_dist_06":"wwxBONZtHTdpKK1LikJIXtas","st_dist_07":"8wMaXp8iff5NnoH1nOelHMxx","st_dist_08":"GuVJ3IbHcqFSquRxrZOiiJBk","st_dist_09":"wCY07bDYRzvjNAZpBFYQyJwa","st_dist_10":"0ceQdD2ITcm9YBiSbxugSYqC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vQKoqYDqgGxffRpl4WXaW2ET4tDxzFUeoriginalP2953D7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":293,"st_w_id":1,"st_quantity":35,"st_dist_01":"Z6Jr53GDzgziuECUeBk3yoZ5","st_dist_02":"ktbmU8V6GCVPoj9m3v115U8Y","st_dist_03":"KD9jNbV8SmdcLax1znaAgy4Q","st_dist_04":"cBPZVdqT5tKA20sVT1lZ2Bwv","st_dist_05":"yNieRGn8wvsbBsryrmgD4Uga","st_dist_06":"emnPar4nf1X0iQOzf4Ibau3u","st_dist_07":"uJ4zj0k954dFcwec1rBYCbrb","st_dist_08":"HaR2XzjllL9r4eFgBqe7IioG","st_dist_09":"CpkcqeALrcZnVxM6QxcbAoqb","st_dist_10":"B1FtfLbBnaLQ0so9ULDUyLws","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BRGG2kIZO7YRubKNv7wOhPlMMgI8Y0C6x02wzOooEKQy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":294,"st_w_id":1,"st_quantity":87,"st_dist_01":"wV59sds6WJrJwndc4zRh5MY0","st_dist_02":"CxK3Cm7IiMkZbtNRL5uOtXSY","st_dist_03":"C0RWtE3MuWWzdb27xVP8PiXu","st_dist_04":"sL1tzJwXXFlEFtRd3E9nI2RB","st_dist_05":"fUxLQO5MBDWJi6eFMv8pzsbW","st_dist_06":"a1548J1UFluPuuSNd9jDkAU4","st_dist_07":"dWIITRaFQqy1E1Ip2Um7gR1a","st_dist_08":"GBE8Izxa2MycKedxp3cmiBAP","st_dist_09":"FZAJdp4IBSbOALKTH0aOj9k1","st_dist_10":"H7ScvqfMZnnj5F1YIMP8P6rg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"emKHMNwlKHREONtR3NnzF3cuJN7S"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":295,"st_w_id":1,"st_quantity":82,"st_dist_01":"2zQNxckP9xdCcM2EjZjVEL87","st_dist_02":"6cazr0JBepSxwRJTwohPEEiP","st_dist_03":"sNfaPFEizd5mXRuW8EbDvVfD","st_dist_04":"2Zap7EHILj7uAbgN6edDDq0t","st_dist_05":"6Bu2GVdEM2SjF0uA3tggka0x","st_dist_06":"EslwlOEzNj6OaFmXynukUOOV","st_dist_07":"LJYeaECuuRgCBjxpS0Ev8b5i","st_dist_08":"EsLErzqRsKvRQJk8gwg4VPiO","st_dist_09":"PqAEKXpK3yrr6zHGYnh7PBFE","st_dist_10":"QRDNvLCjxd2DHOqtubpQo06e","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EnVNSnZp7kk4vKPsMDnoCKizta"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":296,"st_w_id":1,"st_quantity":32,"st_dist_01":"3Ax2sYr3qc3Kh8k5af8zwLXu","st_dist_02":"XtrnJibUsJezXtbua0p6hHJi","st_dist_03":"dTEXnrIVAS8JLUhFS6aq5Rc6","st_dist_04":"blQytdoY02KKHjjFc3O5hb5G","st_dist_05":"1Q1gCx64cGn88mVEY3llkHh3","st_dist_06":"6KzDIguokVLUBCBWamfoKDEk","st_dist_07":"pHwoSAw0mCtpqmLzfgnq2HSd","st_dist_08":"ahkz3LhrfHjRqZGuDcwwQv3J","st_dist_09":"21cC94f9fUs9v7PuWPyA4NGt","st_dist_10":"AoPoEEBDk6NnArQ0YSh0nMCm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Q760pMfgDZM9aI0TyLx8zA6HeN45NF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":297,"st_w_id":1,"st_quantity":85,"st_dist_01":"qu8mnwnjFjBPHbEaRe4y6QNq","st_dist_02":"U31fYqh95QCYlztIFi83LbSV","st_dist_03":"rsM3YpYR9FkVBIhDNl9W8Iuc","st_dist_04":"RWvuXrhf81q2kYgORHrdQ26K","st_dist_05":"nxHlGga5ceTsxt1NEJDDvuR3","st_dist_06":"4bOqUDTBwH4AeVVAIlZ3shOg","st_dist_07":"q79BOLa5o34tSMDC0zeoiVMp","st_dist_08":"r5QTnNHalfkujoeBZfEf8kTz","st_dist_09":"vANpcG1TRIFQ3zQCCYQbMNB0","st_dist_10":"eIzUP1F9l9CzoIAY5FuUKqdY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kcgFr320xlYNQeHbjGFzSHDrWO0NS1ejbDd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":298,"st_w_id":1,"st_quantity":11,"st_dist_01":"IrG4D1Ru1I5BgIJgAX5bwMZA","st_dist_02":"B0Aw8i7cmMbrEZvxkjJ7liYP","st_dist_03":"Zy54R6XGgUWQKXYMOZ9EvY1h","st_dist_04":"7iF3c9WVOQNKBuY1kkH2C0Gz","st_dist_05":"f7nfCNUhHW6KwASc4XsVpkdg","st_dist_06":"Q5xpHRE9HKTjedmokaP1gGhg","st_dist_07":"jdzQpKJywgci9tbDImhoJodK","st_dist_08":"VVioi5gzqKhsrNbJUKa5rEos","st_dist_09":"QRMOB5wVnvXfYeoDYH2dpGWr","st_dist_10":"R20s29yyVRdQXMJDb2R1ty5s","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RV4130Z8WgEoU0wjhff9dPV6P9Q5I3NZykb0zQcrlx14sO5JP4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":299,"st_w_id":1,"st_quantity":56,"st_dist_01":"OddJUybGylQnnYYxkujzMtBd","st_dist_02":"cb843JSiIpBNncjCgrvYrbCQ","st_dist_03":"B1RcH5hQAFtNvtqaBY25jBXN","st_dist_04":"t0yKbtFCam9M2H77Zp7DcxJB","st_dist_05":"EjaSf07cIgideg7d9cGWEqgB","st_dist_06":"BQ789taijJSu2v4JMDWBW5z4","st_dist_07":"BweCb8gvqNLRqLY6BrWfT645","st_dist_08":"HWromMaqSJrLQsY67bcC21ov","st_dist_09":"kknXKTqBv5H7p9RgjqYROUTJ","st_dist_10":"c5fZiBitS0mxn5vS2DERI2vE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DbLo89mlOCXqW3originalChitFBiHOl0dVnPr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":300,"st_w_id":1,"st_quantity":36,"st_dist_01":"QDWztLRjmCLb0Hkp5ZBXe2Az","st_dist_02":"SO2CGu1yV3LXMxjGScIAYTQo","st_dist_03":"VORMlZ4197K9t82X7naXVDf0","st_dist_04":"bG7guEoHYYwqTz8mOnZe0FQW","st_dist_05":"8iHfQj8RhogD7Y1GJsbiIHZA","st_dist_06":"fXQIWW7whpbt5MX3HgNVHEXw","st_dist_07":"JDP6nSUEbTLbdLIdukHh7MeL","st_dist_08":"I9Nv07TwKa9iLSX5IZTWR5RR","st_dist_09":"Nr8bwEUVHlrooXWaqDHVz0VS","st_dist_10":"ogO3hnp0INlolpu0aRDSu5Tp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nsQl2XP93o3BiWvyaKF1a2fyniNeHDBLtDRC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":301,"st_w_id":1,"st_quantity":75,"st_dist_01":"kP2ceha7OTiZt86qB1BlhXoz","st_dist_02":"Dn7l4XiDHdlVVaDasDlhhFUl","st_dist_03":"w4WNZZLQWe36usk7GT2czlAJ","st_dist_04":"hiXydJAMoAt8aC6wQb9xSSoi","st_dist_05":"cjzkzjUB8ffwlnl6OzNsIAcm","st_dist_06":"IBU5iFCO6pWl16wmSsuIJCpo","st_dist_07":"zEjwi2OtCIcaOzfPTROIjqta","st_dist_08":"KiPJEtqaA4MdzGieIu3vMLXM","st_dist_09":"ApejzvG1ZMHCyDybV7GazUhu","st_dist_10":"XkFnWH8ehX1EDpCMCYZtSUQC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nEqd68YF9wNKO5Tj16tkFia1Q8RQ8jIhpmujNJ0sPnK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":302,"st_w_id":1,"st_quantity":31,"st_dist_01":"9vEPHKkWWoAso6XgsF5pKy4l","st_dist_02":"YrTOoSqba0roNDxdV1vC3j8n","st_dist_03":"0c5F1znF48mEK9xbDKzl9Isa","st_dist_04":"cMTD0hIrmcl6ZcMVE9AJ1yvr","st_dist_05":"UpNTAvINDCm8Fw138HX4zva6","st_dist_06":"FWqyEyTkEbX0da2DkZzgnB1l","st_dist_07":"woY0poxoaWzobDhYBpOdgELN","st_dist_08":"IdhnJVEcO7S6qjXae7Q3YSRP","st_dist_09":"YDnTs8MESttq8pduKSSImcWy","st_dist_10":"VOX9F2UQxj77hXc1sbyBT54F","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"shoGJZRQSHM9hzsHuqj4kOCMfcVRJKFUuyNHIdA7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":303,"st_w_id":1,"st_quantity":21,"st_dist_01":"Ksw7z9mwVbhTqCRmA9DPyZTG","st_dist_02":"Gmy3kiFShyoPqKdt2RcG4Z1N","st_dist_03":"wbf68xYdRG0Z5x74JDWqoiya","st_dist_04":"mDHMUKiJW1RtRkHvFm7D16QT","st_dist_05":"FZCuakCwy4FucUvsZyOq8rSi","st_dist_06":"7STB1dPYPM3QwyhSBkdMI9dO","st_dist_07":"NdGa3HCQFjSmcm9qx9CDFl7V","st_dist_08":"pRAm8Krfe5MDQx5eGeTgXsNc","st_dist_09":"swfIBZyqXJ3IF4IxeKEScrv2","st_dist_10":"6iuZRfg9mHOCMatVH8cJ3HzG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dCfKHfStn1fOTEJJavTq8kpbhZmhQMu4npTTArb3WpT8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":304,"st_w_id":1,"st_quantity":75,"st_dist_01":"lMmfme1DjYpLh1vqRUzWi4uy","st_dist_02":"54rxpu9M0U1V6N4mFcr0wSK2","st_dist_03":"xlJ9VstKdcB9KgEvAIVZ732e","st_dist_04":"bAxq4NHmBOwbyy2YMRKGkODu","st_dist_05":"dDjAvpqoUQFOIz2AxUWwFbWK","st_dist_06":"vjO3sIjJzJTJB2W5wrajUPyo","st_dist_07":"fLWh7FcPKZjzYmIM3fyEOdGq","st_dist_08":"2fDSGKgMqsuyeUKUh5a68XHj","st_dist_09":"H8cYYaCsuoWdjUyDU7nhYAyE","st_dist_10":"D57LDbttM4uc7NXtAB3nV4Gf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hf1WxCp1EJ8lyBOvD6aWrGVN8mnimb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":305,"st_w_id":1,"st_quantity":95,"st_dist_01":"DOvfLYlVq63fX3190qlVPwQF","st_dist_02":"JfGBcCvEFceiCD6BSG8rYAiP","st_dist_03":"mGQ7bNny2KvKu4s2nN9zaid7","st_dist_04":"jz6kegUR9XWjfg52Dc0PJqEl","st_dist_05":"6ANr0VDw1Zp79zY1feBMWHfg","st_dist_06":"DC5W5t0WFonjrRxaS48SiM6g","st_dist_07":"bA0RNMlCSIJd60JPkBqdCGWz","st_dist_08":"6TLY1S0m9eShAVUHub8kpEOh","st_dist_09":"rqCn0fBuQ3QbMx0P2odszbNU","st_dist_10":"gSk4xXsD1ZlTgiil2Lk9oPqn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WQWhyQQwcJEpI9naUMQcRN3dKVjpYgbQtzpgA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":306,"st_w_id":1,"st_quantity":16,"st_dist_01":"4wKL1ix5rMpTw1hVhkhxJmmp","st_dist_02":"nrbHlnNUQcZmfPlcdrR9FTbM","st_dist_03":"SiObn0lL2wWH4G1WsmXlaKvR","st_dist_04":"owuJRecMWri0ZsR120NcxVL9","st_dist_05":"j57kRl4vDeier5bUVLOf8bkN","st_dist_06":"YUAszjJiz4rw5tNx2Dq6JGhm","st_dist_07":"a2wXcCTh2c0DYo2TwH1wuPKo","st_dist_08":"JydOkz8tuFFb0dtLQK87cx1c","st_dist_09":"5NrP0gSH6RO3K5QZ391KnIBz","st_dist_10":"eM8UQXIyyLgo5QBYQHZlzePk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GzSdmojGs8lZFbaR6SS6AchxW8f6lcqXnbMQIDe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":307,"st_w_id":1,"st_quantity":80,"st_dist_01":"rQHn4LT84PziIqJfZTG65UEZ","st_dist_02":"JwsxUSA3nqZIf5tljnShC1fu","st_dist_03":"l1nAI23bnF0SWeLxH9rn4vBu","st_dist_04":"0B8yypVxbs983helCzVqHCVu","st_dist_05":"4gnFs8HGXWEdJ5htvExAxh6J","st_dist_06":"LWhOL8MtB7NlH6oWnIcZhvIZ","st_dist_07":"hYlegHpTKKdVb8U7fSoSJbIx","st_dist_08":"zPmKO6hhX5h4kOalTrYX2SSs","st_dist_09":"rCg85aHJTTQVhTGMBJWsBUSr","st_dist_10":"Ev1S5i1yt8rc8wrzR7GIAffw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gysjXfBRLTG4FrXs9l1Y7originalD3Yk2Cvt0u8vkYsbx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":308,"st_w_id":1,"st_quantity":76,"st_dist_01":"3746hxvgUF7hxvpNu408LUcZ","st_dist_02":"i6cD7NXJvckBlG3aaZU9q0ls","st_dist_03":"Mo9zPsIZio9j651yzVo5xKQd","st_dist_04":"RWeunssIkbYPdt84ApnNTSmS","st_dist_05":"Ru9YSpNZolafBlcsdH58uzYM","st_dist_06":"fv7osgAJEsQLur2LQ7X92ABj","st_dist_07":"kw0klsLeN4k5Oe2MeY93baG4","st_dist_08":"N92PSCk7l6PQzvtGsljQLK4Y","st_dist_09":"8DFutCqCcpkYErq00twvrkfS","st_dist_10":"0TDfZ8dTjBaflzlwSylaBrhH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZBUQ2RQuxnG6Xxj3YJa2n4QLjjeeCLdFZL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":309,"st_w_id":1,"st_quantity":28,"st_dist_01":"5QexmJyVaHLQDtZxup9d0MfA","st_dist_02":"sxtMD9azCJp9rbWjeyEaIGjB","st_dist_03":"fApghlyqtwBYasDw3fQxqu8r","st_dist_04":"QHWVgutr1IlTtIuLhXRYjTzb","st_dist_05":"yv5bszT8yhrBEOZn6W8g81ws","st_dist_06":"ELrKDxz4Fgz8swW5vAGqTJ3g","st_dist_07":"EQHRfwHxMyehhitAFRMoFWOJ","st_dist_08":"ezmlZZh4Ot344ItXJVdAt7hc","st_dist_09":"UzCANS2LEpyiXEu4E3KPZZmv","st_dist_10":"JX0Rv4iSzMaLn1k05REL0DpJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3KP8NfiaTPN4yrAzJHSgTNpEYx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":310,"st_w_id":1,"st_quantity":75,"st_dist_01":"DQvzkB1OYwnBTtoMq5MACyMF","st_dist_02":"bqTf26y399x5scGbhNFtfJqI","st_dist_03":"4ZjfOWFoyQFSNBMFLWnfw0ds","st_dist_04":"yfcm52YLJixW3EaXPh7GNytL","st_dist_05":"F7a1VU36Bgz4KG9rkJGjvXoG","st_dist_06":"QxoZPrLivd8UgwsNZA93Weeq","st_dist_07":"sJcnRoiROGMsczO3kLtBtxBU","st_dist_08":"bnNV9qYQknLNJ9vzk2gWhdBJ","st_dist_09":"KUXSEqg6Ez33sqVl5bQmUtz5","st_dist_10":"0gHwnJOiKionuPpT0PuVr3Qo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qL38OiL0ObsiiQKDXWOKfFi4jMliENWm5dkeqyCkaZYiXX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":311,"st_w_id":1,"st_quantity":95,"st_dist_01":"aayhA8hp5GizAy3870Dsj3OW","st_dist_02":"rYdAQXT2PqcpDm5uanrnKL6N","st_dist_03":"QuhuCf5NCt24lk26pdgSKMFz","st_dist_04":"nC5bfaaCpbEb8WlxhI0M6Vpk","st_dist_05":"fAQZzz296efUTJ3cQIIduCFG","st_dist_06":"wrpjf26QWUXW8HnofN8qsjFW","st_dist_07":"5N5U7YoDIndw9tWxm41A4SWg","st_dist_08":"6FSsGApYEwYSYoLFSDRgbtio","st_dist_09":"AxyoVPyPZZaUh9jD9z5kb5hl","st_dist_10":"MSOfa20r9fEQK0iqFNCdNZZh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GK8yDqPYxTga1BV1NDNH9qIr6Vt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":312,"st_w_id":1,"st_quantity":88,"st_dist_01":"tnmiMkdTUxzzJPdndqdcDR6r","st_dist_02":"um0jAtjonlcJXvX2DIcO8zpp","st_dist_03":"nhz0YI3FBLZIfm5fhqWkgEEs","st_dist_04":"O2G1uzedauIqUnGdXDkiISxJ","st_dist_05":"FhRjiGSC3gK7uROH5gUYjrMi","st_dist_06":"PQvus3nnkjLQ3qYAwJKlcbVW","st_dist_07":"L3azd1CIy306Mnd2LjG91ZFU","st_dist_08":"xHbxNFb5hyBpfPgDkcwf89g7","st_dist_09":"ldCb0tLWVTFGs7Cig2mE3aQj","st_dist_10":"y3hiubmuE2JyQTLi4eAaha7n","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cIy4qqE5KpbFdT9jCmEBVTawoiVCgWG5dJEq5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":313,"st_w_id":1,"st_quantity":71,"st_dist_01":"ypowBrqojdW2sxgiwAc7sVrm","st_dist_02":"55rWXCgqHMVvVgjHBb5GAp9O","st_dist_03":"XVFqhXNHnrWGdzEhBKF3XtbQ","st_dist_04":"zm24J0HDJ9UDblsrEmPXCXGi","st_dist_05":"CIywHMibQfd7EKd8GwNq9m8Z","st_dist_06":"1nDgC9EIBiygm9QxPC8ALiqe","st_dist_07":"ixjIzT7HQAB9AtojyNwGTe2n","st_dist_08":"IIFsJgQVrPyluszq8xAflZwJ","st_dist_09":"oea1G5MATArqnky3FlLKFqHJ","st_dist_10":"FN2Onm9nL2ddrxuUlSoXP0C8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nsKFcr6cVEqMeLUIIwiTdwdP0bWgqTamFV1Nmr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":314,"st_w_id":1,"st_quantity":82,"st_dist_01":"0PQpoB1QJmIsXefReZfio8rE","st_dist_02":"1oM8mXoMxP7XDDXLc43B8Qet","st_dist_03":"vI8A1g27Xj85Itd3JETnK1bU","st_dist_04":"03oNoJ5dn2mICxmowm2I6kGC","st_dist_05":"umEjpvcggfYxFSLS85XKcXlS","st_dist_06":"203jnf2QYbAUyVKvsAWpE8zU","st_dist_07":"oEBDG1vwavVeryRyQpmmkr54","st_dist_08":"pNaMLjSch5ePpDh2k4xkQkMA","st_dist_09":"POL4eM1Hp36xbdnwu3VsJ7lK","st_dist_10":"B2rJ0YoXPPYmmyevg8nHVGuo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wJ6fj53M8Xgm8OPZLSUwjX7nbaYeIwTLCAk3ldIhQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":315,"st_w_id":1,"st_quantity":85,"st_dist_01":"fer0HBsfibwOZUe40okGcuKD","st_dist_02":"SE2DR422YaIKxpHF5igxP1Dg","st_dist_03":"H6qANEZznIAuOt9WH6Ga1krT","st_dist_04":"ivm3Hvk8xbVKSkf5HzWtJW0C","st_dist_05":"HwiZpfREKWzvi382ST9IrUH1","st_dist_06":"hCdlQgsEMPpVhdEMIFCwPV2v","st_dist_07":"iwph5JUOmxvXFlaoN372A0wB","st_dist_08":"j1G47PIKJDQE2w6xyAbfdWl1","st_dist_09":"oMlgbEB0Nz9IphamEE92i2FV","st_dist_10":"av4fBC9mV9e0aUtBx2P6bdGn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"n8HuvgTYbWADvvPl3ABYkeYvknHRYmafSq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":316,"st_w_id":1,"st_quantity":71,"st_dist_01":"roVKgazWaAbpU5r7Q1on3tvL","st_dist_02":"MpFJNt8XhQTzvSHRYwDSHqc0","st_dist_03":"T9W7b8L56IgTan24xzLioH3h","st_dist_04":"ZclyfodPZ7j4Nz0c4VgqkDNd","st_dist_05":"OasvccXRfOuZ958bwr1iUSoO","st_dist_06":"I6VLRf2mGYgGqVTrDBbuXOZt","st_dist_07":"NxaNiENuuErfwxJcdIFjbyOb","st_dist_08":"i18zDlTOexr7qgbeygm48vLF","st_dist_09":"xBZsKlEfpLI5DYqySQgXLNbe","st_dist_10":"6IXllrKx9jLuLwC67uvGtrqp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"52K0anhIQUU3sUpUEMHdtvmoriginaldAiZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":317,"st_w_id":1,"st_quantity":12,"st_dist_01":"TPEv8LgEk1Ad8FPmYKrn0QpV","st_dist_02":"MIl8mYLzG0FA8jedefXpz0s6","st_dist_03":"UAUwRLpjs7NpFMtuFY6sUdlz","st_dist_04":"AayfiLGMGTXXGwek9rqA09zf","st_dist_05":"Mph4elOhC2bycJtWQB6oP5rg","st_dist_06":"fPq1ROJUSdwGLMx2HypVzq1f","st_dist_07":"8AoQtVggG7ICZUKDXFtYMWmF","st_dist_08":"f2XWWzeFrmFLA3eWz0UH8eoA","st_dist_09":"SrfNm3dT3c5twtkbJRlbPm1Q","st_dist_10":"OcspNBfNp3ucLTdWSK29AoSK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DrcStlweZyPQoRLYckA2gA5fFHYH2DnVAZ2Ya06cUSkmpXVcMH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":318,"st_w_id":1,"st_quantity":86,"st_dist_01":"YAkFl4MYvyf4kmMoHyrJguRc","st_dist_02":"uiCkiaXODa2KMm32UgNEM75M","st_dist_03":"fEqRkiBsxGnx8bcK0aD8QIfZ","st_dist_04":"fO22J2ZoO55la9KTa7rXDY7z","st_dist_05":"gTBk7C4ZESTZHcc6qqKmD8q0","st_dist_06":"y9c8JNBXS44qA6sp5bEZyKHw","st_dist_07":"VLTbJhsuaWhKVDvjXw6fSKdR","st_dist_08":"lCkJwCcgrcqGgjUAcCKZa3pu","st_dist_09":"sZiSO2kL5ZnD0gFCoFT2MauA","st_dist_10":"A3WYkHd6IJJF69DdZURYUgKx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g6dVpugqGwmPBEtUuQjBSRE91r76"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":319,"st_w_id":1,"st_quantity":61,"st_dist_01":"5r1sP1wKQ5wTke8EdSnLBhF6","st_dist_02":"tsJjE6c9MewHUYmxu8YoYu8K","st_dist_03":"3iYDokMIIDwUy40KUDYUFwyp","st_dist_04":"nMRmxyfvDRpek709d8W77Qrv","st_dist_05":"07gCXO5LeXEurK2CcA1L15Fn","st_dist_06":"bup1gqcWtlFFlzm5UyxJY89X","st_dist_07":"nKMTleNX3g4Y0SQEw6QUChZt","st_dist_08":"a1XqFjYuRZClSIBR0H6YImGD","st_dist_09":"A2mTCrQTsjA1NTXaiYCAzXgo","st_dist_10":"ASzMyl2cjQDnxABWbYgTaq7e","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mYdgzfkoBPqEg8m4KXcpX1GQohnqlD8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":320,"st_w_id":1,"st_quantity":83,"st_dist_01":"TRjLMazOQWu46ios9otyEgbi","st_dist_02":"7llmeCvxmSXccTGoxJlQwCAj","st_dist_03":"a9Da6XdpAtuGjWr9G8qiauR8","st_dist_04":"XqEBDTONNfhRSRYxei9k7Tg8","st_dist_05":"BsvkBt5o3qJe6OsLCZjHr7fe","st_dist_06":"LxNqE5CU4QPz7YZDHwqMQpa6","st_dist_07":"58zHza2E9xkg9Dz4Duti569K","st_dist_08":"QhYpFUKzgqYTZgBQDIro1dJh","st_dist_09":"KfUr563cmgjp8MrYXyk737OM","st_dist_10":"oxYC59fBMJBf4hgYnt5QjK9P","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"e6P8qNQsNAnkwmbR6w6BqRwfYscaqOUdAHCxnIY90wUYW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":321,"st_w_id":1,"st_quantity":93,"st_dist_01":"8jlrbjnqZqFMTIEmWsVws4Kf","st_dist_02":"NcMOZue2gFImfSjHEoj1Khd3","st_dist_03":"TUGCSrOM3G570O45bzFtPGxd","st_dist_04":"a9mLr7ojc9Vc5xz1GzUfDGak","st_dist_05":"zLYyVAu9Kdvt7VZ3lEgRG82U","st_dist_06":"9v3JVThaiNUIxwVMZcFBXHhc","st_dist_07":"mRfsP0FKe6cm6oO5Qrk43KlV","st_dist_08":"aSY33VVXLBgOFi8HgEs2iDOE","st_dist_09":"t5MIeJp6705u8ex5m5foIti3","st_dist_10":"jj3fisGrAMhRCjjt1mIULKY8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EDWIKCi0XDYD44FayaoBnel4N8u9p"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":322,"st_w_id":1,"st_quantity":52,"st_dist_01":"iFBcCC3ZSGhoQBNZtXnGt1ua","st_dist_02":"8A6mM2AuD7M3TVzxtwANsEDb","st_dist_03":"EOFa8A7lTl1wPvw6F3EuQivr","st_dist_04":"BB2qnC5Dy9t4qtT5uGg29uAz","st_dist_05":"WM7eZimvvhDzbjd1XQ4KYE81","st_dist_06":"RhuhWY7lc4SmnFp9DzVlqZj3","st_dist_07":"DfJUMjBnZj7lCNdjMVy6MteH","st_dist_08":"S2Dqz92auRqRegajlRIpdwnF","st_dist_09":"KQN0mAvorrQ0zKiqkwgIu9xN","st_dist_10":"BUfkGy5UW77c0URE8f85xeRY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XmLTZPWhmMYQvogh4Lt7gCc5sEV9vgSvnsqtHnxo4T8Fin"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":323,"st_w_id":1,"st_quantity":36,"st_dist_01":"TooQphr11s8IEdjeJ8KIv89y","st_dist_02":"3kaujQDnd8nZhomMEllGQSiE","st_dist_03":"ZRewcnTUWEMOKZrqSghp5Bzw","st_dist_04":"RCHkIOb5RcpPEY3bOOxh5CGm","st_dist_05":"JCeFskNlxXDpoxFzoCf8eo0U","st_dist_06":"JSotMFswUoc6VISsXqUNpubT","st_dist_07":"pMjGaeSnW3C5OlhKY5QCtdSQ","st_dist_08":"uutzymu0QYd6mE11XKo3CPRt","st_dist_09":"ERpey6bFaMHpkwQt6jmRPJCn","st_dist_10":"9KpgPWYrSByYIdv4BZMVJRxW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YTqVW4G7ySK3pYeX25Od6ITUCZDectenxCOhRBk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739236,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739236,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":324,"st_w_id":1,"st_quantity":96,"st_dist_01":"SDoRA95MvhzK0hiAeUHyIBEf","st_dist_02":"OIg4qDocNeRtvZiqHMLero26","st_dist_03":"8qqCETUhQiu7D8ymU07AnXai","st_dist_04":"d1vkhikfRiRvj9EpBmCHOMZi","st_dist_05":"yy9HaZIYJdY96E4wEmcTs4m1","st_dist_06":"4Prhn2VSvmOXUmwxzltMGGXc","st_dist_07":"y880EJTFp3hClfGV0QnP4uAB","st_dist_08":"WuxOmUZMPgW8OmFzmE6kPhRV","st_dist_09":"7Vt4pI9YM38aMjgf0FOxWwcE","st_dist_10":"a5z2vkQQK3ppwUD2DdQEUEPd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AZnQFIVqV4LhYgJXtIDmFGP76KCa8eTSmW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":325,"st_w_id":1,"st_quantity":72,"st_dist_01":"i2vws8cSkfUsPT1Mfb1n0IyM","st_dist_02":"vLJwp8eaNByqLcMJndJrjI02","st_dist_03":"FOH7GBZ90Ws592zrjkwAPyBD","st_dist_04":"E9rLdx3lnslG77tIYnR6IIuH","st_dist_05":"7hgvTqhNj1GSxRPgipy1YxYd","st_dist_06":"sLV9VQuL2pJlCBqQYZkc4MO4","st_dist_07":"Nk9FpWHSZIhJqsCYd18GdGbQ","st_dist_08":"RFFxJyuNGvfW1orsn9VdF1sf","st_dist_09":"nFMl3wxdPHErR9cDUCnwTWHR","st_dist_10":"AftOVmeAtL2O380VMrhwiveZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YX4tn1qPFPoriginalQjoQr2d4To9L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":326,"st_w_id":1,"st_quantity":51,"st_dist_01":"kJ2P3Er2FUhvbGaeA8cxdfnZ","st_dist_02":"iOHb4yFBrKswgb2V7eXSZcFA","st_dist_03":"7cZTyY5xcVGq7q6BgbRcW34d","st_dist_04":"AyqDR7FOzIvySYNPNED6JuI3","st_dist_05":"HN4bcmc7E4jvssvAX4opRPXy","st_dist_06":"E2kJK3cmwk30meZIO4lVpDxG","st_dist_07":"G6BBclUfO1JG0XJWptVSU1Lq","st_dist_08":"tWqk8YL0aBu2STr6UuvTupWs","st_dist_09":"1D6ws8R4j6yhZiVIVgYTYlzX","st_dist_10":"ZiCXfWS8bioAJrxRBoy8TTFZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZIOK5gFicz0Aj3Jx9Jy8r70YJyGxE7WSi3AHPpjKUe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":327,"st_w_id":1,"st_quantity":52,"st_dist_01":"h0hhalVlr2RAvHGUDxkc3u0s","st_dist_02":"n0xFQTf0QCjaLBcjGS4BgeVS","st_dist_03":"jRV7MKizErWG1xBH5ZVsOIRW","st_dist_04":"tL324k9NphArywGSbN5T9agU","st_dist_05":"evZuE4RA5xTjtRkU4RAojHpQ","st_dist_06":"Xp3XHeOP3XHHQH4I5LTvYI56","st_dist_07":"PmPLqrp9a1yW4lyHEQObe5P7","st_dist_08":"h0eW18ItzEM1V58vyo51LDQa","st_dist_09":"R8RM3LKvXYmbviYEoCmnFxJb","st_dist_10":"VYFSRVKc3Fabew82iH2lwzTa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UndauiJSZj6tOd27nv8Z5ljUyFuqTysUy8OxgIUPj51"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":328,"st_w_id":1,"st_quantity":44,"st_dist_01":"d0ww6Orj4odZkKCRxlJei4ga","st_dist_02":"7RUUGRT9gKQ7KLpoWiiS2EQq","st_dist_03":"xmIlxOiFLksjTeqR7QSPQGm5","st_dist_04":"jAbgMawTBhluljWVDKhX3lRV","st_dist_05":"1vXDwLM0txhNWbinMCYIbzVl","st_dist_06":"Zkm9sGGFCVazLBaGFY8SXngq","st_dist_07":"L6ftAdBdSO33eGAdUvFlgj2x","st_dist_08":"F7uBjKf3OMJc99or6OIczoNY","st_dist_09":"hDv9WaQq6EslnqNOFDzlLfdH","st_dist_10":"KUfZBY9CJhCh6GO1SXvRkQrk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ARIBQmrxPpKHubLxXnd7gp0Pvo2CH3exrIagdd8v4v6Wg4O"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":329,"st_w_id":1,"st_quantity":83,"st_dist_01":"wWLJgKaLLn8z4pnMMkJJKZp7","st_dist_02":"pmN8TLq8kJ1KUqGc61ccQioV","st_dist_03":"bbLQXJJJm9xzx5D6W1G70NAz","st_dist_04":"dMLctm6nMSx0SaJ9uxrTwjKg","st_dist_05":"OR6rDRs2QU2TDRwxgnljPe07","st_dist_06":"woS7wWPZSFLEn9lJstVj85FJ","st_dist_07":"Reun93GITWh5KwI74XRunFO4","st_dist_08":"0NJ2ucuuGe4mPQImHYBOp9h0","st_dist_09":"7pPvjBf30qKM08HG2o1z5Sao","st_dist_10":"g1f4bz52Ej0gwD7MElFkfCib","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Q84BSVr10oN5gxZ10h4MEAbNR2AueENshUSFS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":330,"st_w_id":1,"st_quantity":92,"st_dist_01":"LYMCtnXNKrurbQhXFnXFjpbQ","st_dist_02":"4QAgctude0Y9Q1nDLg8BDc63","st_dist_03":"yLxJIkHaiqlRipO2ikIRK0Jb","st_dist_04":"1GY5HeRdF2ws7LN2LF8fPEAF","st_dist_05":"22TAD7aA0EAhm4U2ppB6lRu0","st_dist_06":"0FGmoCZtt9a5vAVS0DmYKw30","st_dist_07":"GkV1YQFcAsrUXJkDeENrcgXK","st_dist_08":"Hq8fTmxexszM3hroV4gh45RB","st_dist_09":"D2bBNx6Qm0fDNKTO6auGGsYp","st_dist_10":"X0uN3dQN15yZzaEgjza5gjqu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4kfHOPoAgpsQMggCvOoriginaluDGmL2f3Do3ZTYnOEJOY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":331,"st_w_id":1,"st_quantity":67,"st_dist_01":"wk4hPhl9PozpnuBiwKvOEJFd","st_dist_02":"53SVRjeC44lvZzZhf6k9ng2R","st_dist_03":"Ou90eqIwALpRDdge16nz4R3Q","st_dist_04":"22mgq4fY0umWy69cOgK3PEpT","st_dist_05":"QWECtXAJ3SouvPBmXfNxDnGg","st_dist_06":"Nliy2kbPgkXCqgW7Wc9VYDDF","st_dist_07":"WsMQloscWJEjloOogpck5OlR","st_dist_08":"DympjT2G6LncP0KHc0jVrH0p","st_dist_09":"JChmeSUpgE8y5mp5M2oj5kix","st_dist_10":"5bLVmIXUa9dZt8SVLhZqfKGr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jZHQtKnyd8UywOM0ItZMjBifI9aHOcYDhn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":332,"st_w_id":1,"st_quantity":32,"st_dist_01":"cdsrdKLmk2dTzVK7tNRIuNp1","st_dist_02":"4wUBaQ6HCKaf9G7fBIOkyRwa","st_dist_03":"sZsHIYD5MshJGec7dzplgCEx","st_dist_04":"Bs171SmndA8z6BKUKGAjyH5b","st_dist_05":"43hmaOGhhqxxpQvaxnvLEVkq","st_dist_06":"7LmfKK8RxoIwvRYQhPa36bAm","st_dist_07":"eNUAiRS3q5Tf0LgYrxcPSCXR","st_dist_08":"g8u36eY6Y8pDmHhrYnRwFb1T","st_dist_09":"3vgQdoGVrNLevdXSZOjfbOdj","st_dist_10":"txwNxfIcPXojxsybfagiCprt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Q7FsxfuS8aHb3DbvkFtKmQoumxFIB9FRU6KtujLaW5nyaZz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":333,"st_w_id":1,"st_quantity":65,"st_dist_01":"oib3tI4lBW0uZJh0wQRYVEzu","st_dist_02":"Ax3lomhNyvTCs5No5fat5QhG","st_dist_03":"apCHQ5iuWIsa36765OFwkTFX","st_dist_04":"mWgTYRqeqYQ4m4lcxwB6DeWG","st_dist_05":"7Bq1syIRVQ8t53SfJokedTSp","st_dist_06":"guxWrfvF9cBMtucdL0o6Z9Tq","st_dist_07":"A1EyvHMd47SJkPmc89Nyd8Fm","st_dist_08":"e50FaDaWTWqUVZlIhYceMB0D","st_dist_09":"edY7AhlCiiwROcGXQEfu6yg8","st_dist_10":"xb7JrJQ2eggzbg6S1vvunOuA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yZjC7CSV0Oin1NemC635ZD5qIeDq9zyeQeJiv13ifbSU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":334,"st_w_id":1,"st_quantity":11,"st_dist_01":"dZfi0ottSAuRuvyKp5WEORiI","st_dist_02":"A9LkzEsEAmlBt0JtMrKS4Nkw","st_dist_03":"2OUl294njZQe0F5FyvoUoJbO","st_dist_04":"Isk8AMZvRhURNUilmlP830T6","st_dist_05":"5qJOG3sfbBwdmNeVF3SfcRTE","st_dist_06":"Y5kZPo1U13r9xR614JyrXX1Z","st_dist_07":"OchwzvmRwyajWnNwLK8dGnDf","st_dist_08":"GreVV8RjPBw4iexaKW7usDGG","st_dist_09":"D328vF9JE7KREuFAcqZQz7Jd","st_dist_10":"QxgXSTtdVxNnrrqFPHDbNCp6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"djCcayvTRz9NiF5hzoYUnrLsm79HtX4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":335,"st_w_id":1,"st_quantity":58,"st_dist_01":"5icvF5JdZOvlRkiCmhOmzIWb","st_dist_02":"FUyOCLs9ldjUuXtVAciDkIHl","st_dist_03":"osteTxObShW9anx1d8ks8lKO","st_dist_04":"l0tCYWEcM9Y3LGXxLdOqzt1T","st_dist_05":"NZl31nC9MSRL5UuKOdEwwScJ","st_dist_06":"9CKXljilLCrJwxT5smC8JbY0","st_dist_07":"jEzMSvdfaNYEQ5mf4eFZ3pEf","st_dist_08":"hCgYxqTY55vWqLSxprI6tAVt","st_dist_09":"f9zMOOyYOHLn6fZnS844gZVu","st_dist_10":"Zc7pjjRnZ8x8MjCkJxVEmrVd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"G5AkfJlhYsRysd2ozNVM9a6AonbT2I5QUXvXMsNojvJ7h96QoV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":336,"st_w_id":1,"st_quantity":86,"st_dist_01":"hn0KVo9PRLZQ0gZf7Okck8Vt","st_dist_02":"FDuSz073rwmXbv6Zu6AFuldS","st_dist_03":"NM0QuV0AJDxjSszu2JCkal6s","st_dist_04":"KkNl1PSwomeqBAD6rSq5Sab6","st_dist_05":"1UlNA4AsNErrDOTXK3FiZx68","st_dist_06":"HZFI0CP57loMcJYLS8CaXn4f","st_dist_07":"uRFWzBPiGo3fsKcefbQtECB7","st_dist_08":"bvtCy2ZHqSMNXUbSSR6NdTQP","st_dist_09":"uCrwnXsjk24KV9uuLbT7YaY9","st_dist_10":"CUwXi1tjXe9cnjeDORdt74Rp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"originalmsNEf3CGeMDyA6GCfTzxjdvRt1PxoTqMAuKlA7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":337,"st_w_id":1,"st_quantity":92,"st_dist_01":"3Pn3JgOpQACsN3SllGWZY5D6","st_dist_02":"HtlTVR35IRO3IW4K1M68OnY3","st_dist_03":"Qj8URS8GpzDzm87TAWmhThJz","st_dist_04":"ARi9bkKQmDO6l0aS8qQwTIZd","st_dist_05":"iWG8AvRZugv183AOWXg5ghwX","st_dist_06":"zhD6n5TXycYWq19Lpxy33L2L","st_dist_07":"hyHTPnvnnTb0MWdcIDPJO4gG","st_dist_08":"mwr0MMEGlfGCbF3NxdqB5bPC","st_dist_09":"KlnlxsIBYdwk0DJ6getrVaoo","st_dist_10":"36V4pty2FOamrTaB092NUjt6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PnFSypYaOuOBA5KwEbcR6pNq0cPXBpuFG1vNESQnKFZeuybQNd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":338,"st_w_id":1,"st_quantity":93,"st_dist_01":"tMwsA3B56CM0kmFOlohHt3SO","st_dist_02":"hkQfzeqkrWyi7sVMlyCvXxmy","st_dist_03":"bPca6WGonuGJz2x51pI0WxGA","st_dist_04":"cQePJMfsdKJBgIy0tH5uAmct","st_dist_05":"yOZj7MkVwOAeZXDZjUOmf6SN","st_dist_06":"qM2yYJmbImKvyHsBsBvzL4dA","st_dist_07":"yFezF2q6TPGn0nz7g4KCdWSn","st_dist_08":"J6gKICtjBq8QUmXhdpe0x79D","st_dist_09":"U3s9IeOPUQc03L6lrNy9Li5Y","st_dist_10":"DXLy0SxTsAAfjeXobUlF71GA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7NlvaSlw7U9uBmUfh7SYI2KyQXfC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":339,"st_w_id":1,"st_quantity":82,"st_dist_01":"i1Gt3yzDfCKQaOmPVxldKDHA","st_dist_02":"agut8FUekSyyp5r7LAk6kYgT","st_dist_03":"i1hTIS5zSsB3tExYaxq4d7Dp","st_dist_04":"UoHTg53eyLADncjEetgeBwVo","st_dist_05":"4a5cspDhqEoI4JdjBuqW4LMR","st_dist_06":"uuCsTzeO1MNcmBJUDIxX3mmb","st_dist_07":"6xoWYR4NsgIvJqAvJTOLFTk3","st_dist_08":"LAgWfO9JtzLg58KCMCzqvlu9","st_dist_09":"GSmNWG6YKAwSEWMhHTKU5dm0","st_dist_10":"7VXdmdjE0xvHLGCN6Z7gVxhy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bSIdLUXCRywPFCEIDeZWLkfQI7NZ4hATrVKkRXP7CgmxB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":340,"st_w_id":1,"st_quantity":44,"st_dist_01":"yKVRptf3H80YPGUgYrXXnTni","st_dist_02":"IlziOpttZJQzZfL8JcJErkXx","st_dist_03":"5IwAPhpHzZnyNQQkTtV4rRUE","st_dist_04":"CQJlG4a9MA0o0elkFhXl6NdK","st_dist_05":"N3SA1W0HSmm3CAxAqdhFOhPn","st_dist_06":"gXdL4fbEpb6nxCGjeK7z2eCM","st_dist_07":"PYSCJ4TGtSEVrlymX6j2LV1c","st_dist_08":"7AZL5i66pZ3ZINuOsWWHI7DI","st_dist_09":"OaMILBi7RUAcEtTQuenixtMw","st_dist_10":"i9ItTPtQSOpDfodhTOxerQz3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"w7fc4gSrVE6aXHjSYInLoriginaljNv6t4jd7hOBHFORnj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":341,"st_w_id":1,"st_quantity":52,"st_dist_01":"aC6CRN7o3qrYoXkvEUc4bdqE","st_dist_02":"5ApQQZ320obXzsjhv2HAqIdE","st_dist_03":"IDIcPFi2saM6wUgEkkHZ7BtW","st_dist_04":"wiio2JBGqvRBebK2N6QuIME1","st_dist_05":"7ZtiJuqvKKESpYUTaIvdwySy","st_dist_06":"Hl6xwJocIFThmJjLzosEdu6q","st_dist_07":"bLC56mPNHbhFLAoft10ioOXp","st_dist_08":"CNZx2w9gRz1VutaukAtxl6yG","st_dist_09":"gtHsKHrzi2zurzRmNoO0I5d2","st_dist_10":"noEczeLWoAJ33HDyLidTz7KO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kb8G8zwQ4iltG5Grqx1cTwUC3B2vln63WXOEtGLagObybX2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":342,"st_w_id":1,"st_quantity":56,"st_dist_01":"yqASrSQ7fsnuwXD9PH7Egh6Q","st_dist_02":"Ag4h4DdRHHHQHZQ0vQuXXpfE","st_dist_03":"POIthN74M6BEvNQ3dtvQ3JPP","st_dist_04":"5b2mgIpZnGLKLtkEnd495eKN","st_dist_05":"5iXWZFOOxZ5d7qkZG1JtlF7X","st_dist_06":"xdKeykGN1ZuFTZRI7zuql7It","st_dist_07":"Hf1AvnJeo95gmv7HtINUQ2H9","st_dist_08":"a7umjiPlQFZkqvYRnsVrUpoO","st_dist_09":"hYOEaA17f45sy8WcwT8ojWhi","st_dist_10":"I4yWjsBJoD2qWlDhCwo38Ku7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ey3DGwiRRNhkHmzpb1Pu6CMciKjlEbsYbpfxMix3U5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":343,"st_w_id":1,"st_quantity":82,"st_dist_01":"lK1e1qfVJ4uSIjKtvyzyozcy","st_dist_02":"2EWYjejX1s2RFy5tQq3kFQiG","st_dist_03":"I22epXwstB5QeiU2tYlKz5Ra","st_dist_04":"5TvY9zjhaCfX4ubg6sjN7C7S","st_dist_05":"fo8dchvZnOZ91v1rJnuMxCOi","st_dist_06":"08VBKpe29zIqAQUwI5SXJS2U","st_dist_07":"xjr1WQ95m3kdtVMo32ybi8af","st_dist_08":"bfDut19y7XIbBx0LghvlHxWH","st_dist_09":"R9SKuOI3osTi1pQIyHwSEQXl","st_dist_10":"7eL9Vzqqc5cZGtkFBQxsNTye","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3VpMPheKGxsJmeLcld0cMERuXU7XlAYIfzJntJmP40YW9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":344,"st_w_id":1,"st_quantity":14,"st_dist_01":"zIJRjolmUO7YWC5CdeNKETw1","st_dist_02":"SY9UB3G68Ziijve4JrEDZUm7","st_dist_03":"yLx34czXS1l64vcdwLq42Y2z","st_dist_04":"9egzqYXnRpTAViUB66bZgrwn","st_dist_05":"vcoePSlmUoI3uywFve64Seq8","st_dist_06":"wtYZnKkkDFieGBd8OnRyC57b","st_dist_07":"HocAj2osHEF970shn5JEURYE","st_dist_08":"mGwmIarptckTzPkyjhHT2baH","st_dist_09":"3BI2FM7RgOHtpowdxMmbmG7G","st_dist_10":"Oki3BNAjbK6FKh0G1phZrjAM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eMmocEdJOY2rYoriginalLpdt3UWn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":345,"st_w_id":1,"st_quantity":66,"st_dist_01":"8BLNGofmNfQVaOZkWqt1S2gt","st_dist_02":"IwuIevE9JMsjNt2t9q4VHkfh","st_dist_03":"RkNefptqPFRUQDjMVxA98fYn","st_dist_04":"o0gTuCHuAwFJtk7CSKuedzUA","st_dist_05":"769nTDxFsMeiifWREzNqXiyM","st_dist_06":"a33SUb9sRQOrsgk02GkHdzw7","st_dist_07":"oY1rzYZUBtGU6jfm1DnXJv8M","st_dist_08":"I3r3nR8S3lz3vQ6WqCLCjIff","st_dist_09":"4svJDi6hS9V0OOEGtnS3YT8R","st_dist_10":"nVqAdrc88mJuhFxadCqZFThO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ApSMsKWzHUXCwSFmyBGy4wmJFq5z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":346,"st_w_id":1,"st_quantity":52,"st_dist_01":"vCn1L78vaYbiFcoyTy63oXZc","st_dist_02":"4fwwbjj7IFH8gXg7ouVyqs5g","st_dist_03":"mfTl5qxk6jUra0dWEMe8Kxbg","st_dist_04":"Wb84mWtAynxmvTg8UDbxDdYP","st_dist_05":"bLnEbC6dxbkRNNH6TnTwR0S5","st_dist_06":"sWeA5DZ4Q1ntvWrgMsmn52cn","st_dist_07":"BWbWLoi6KyC5bDy3Vtz8AlE0","st_dist_08":"foObh95VqKfWHLgK8NR4bzwG","st_dist_09":"yGRm6XlPQWoZuhYMsnwczTPn","st_dist_10":"ADMRw0bFN5pgrGdpE6fxvDp8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"poFW1alcMDDPNoriginalvXoVov8fE6QnPCJKBV6jb7W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":347,"st_w_id":1,"st_quantity":67,"st_dist_01":"2H8vddunrEAayzGPLznY5eEe","st_dist_02":"etpqjkjccDRCLQrXJWlRopRT","st_dist_03":"en9O5mUfEDiHc07InRkKno1Z","st_dist_04":"wxItXAbYjm12JkZqm5CZJWlr","st_dist_05":"GDfNT9rwykhxrT5a0wytO7uY","st_dist_06":"CT9GlwIFtYfGsSQO71xqBQwS","st_dist_07":"f5yPLabRwdtuPkH4I0VbSOrf","st_dist_08":"blFqL4ZsNk878GUW2Ebs5g7b","st_dist_09":"rhjNRYMfIm0nDFhObifkjA0v","st_dist_10":"9bqRf2PRcdzufE05cai1PRtn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XQSoFT6YngI7dguLc0Ra1ucb1fXobHjVIClvCnIIhvjgMt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":348,"st_w_id":1,"st_quantity":25,"st_dist_01":"nvUhLTbQb3gNdsb3YABRYuum","st_dist_02":"KBj8GmB87eI5Fb6Tn6e5IX9Y","st_dist_03":"bTOhlCdz3KvBkAHYilSKxjUG","st_dist_04":"DrGY0LfEmAkLiDLApBeugXix","st_dist_05":"TsRmPXkYsudAF6VTSzg6R94Q","st_dist_06":"Dv7qWFHa8OQT3QCu4GVFacLL","st_dist_07":"uoOLcOO3R6RNX06cVRgIN0xm","st_dist_08":"lb6rr7BoejzKFxT8wmduDFF5","st_dist_09":"G6QEb4hnonREaXhRs3TNa7dF","st_dist_10":"nrPwvA3I9tNUivZRbTOa5WSO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hzKrHczKhTpHYDYP4dlLEnkilVOqSvforiginalO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":349,"st_w_id":1,"st_quantity":67,"st_dist_01":"iA8jNRQJ8QRRuSCCfvB0abod","st_dist_02":"zceWotslMa66w5VrONyB9blB","st_dist_03":"un0Cvlk5DSWYD1yC7MvdPURH","st_dist_04":"BzttKx4y8O270CgJFxGjd4Ar","st_dist_05":"ykU9bn8iDV1yXteeciwJG5cU","st_dist_06":"q0Xuw69XjrFSCHooFAb0iiOs","st_dist_07":"pz2khTlq16E17748tKty2Y5U","st_dist_08":"35SOJl1OOcabuzDU1nHEZCPL","st_dist_09":"7AoPpcZ9sI7Tja3ChRv2rFPA","st_dist_10":"NMEVnUwNgVJmSCaBCESX6whL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"htY7lIBUwMs4EOxj1ESPOjx93lElriMCoiVGTcUX4cIU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":350,"st_w_id":1,"st_quantity":53,"st_dist_01":"qVwvSjpzlzZoHpDSRfEoLkL0","st_dist_02":"GOlCAGmRfRE8TpeVtAvSvaUD","st_dist_03":"CXv7DEge9RMoVMbmSiA5Agfi","st_dist_04":"IgR5xgi6sJU283od1La4nBHu","st_dist_05":"FuonqFzRQcrh1a5eb3v3PGRY","st_dist_06":"a4PAyaXcNO3rgwjUlLBB9OET","st_dist_07":"9vc5buJRZv2RQtFbyau3YeOA","st_dist_08":"9kCFDHclsVB99j8SUQ13jXOs","st_dist_09":"dP6DF2Ok9zLST37MPaN2Hkmh","st_dist_10":"fVXQVLpzF62jsOpx1KnUJyPn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AJq2BIezWG6mgwFjVyRWebckDp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":351,"st_w_id":1,"st_quantity":53,"st_dist_01":"artXz4REpXOtNNszefJ6GXZM","st_dist_02":"ciFXYPTbxXJfI4Zi8izlGVwV","st_dist_03":"GdPuz4X3uytVcfcsmMN6odkS","st_dist_04":"7JaTVPwJhdrv80FjYpdzjQGu","st_dist_05":"Ffo766QhEcP2aJDQBiC0uKOV","st_dist_06":"xgIPN2bhzwHRToV0RmoGmQJ3","st_dist_07":"rJSxvZChzD5kTk851oBEoL1X","st_dist_08":"t04eIPT04NOaTSFOLNSmvptM","st_dist_09":"kOU0F8xJfO6YrxaMxVaJM8C8","st_dist_10":"g88SfCZX4uLhmDLvi33djXdQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tO7HcnykJRTyyQgEx2W2N4QePSJbpXgRf5Nufh07kWFTtrAr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":352,"st_w_id":1,"st_quantity":78,"st_dist_01":"ilMmB8GkQP9Fxrc1qD4YSkJt","st_dist_02":"sBU2AWL1zPhHhnS0phi5H5v0","st_dist_03":"9Y10zXrmdrNEhV11FoqiHaEM","st_dist_04":"V7p1Iffik8qpouqME5PkXGJJ","st_dist_05":"VCwk1mQ8e4lD9e3fCMakXGgu","st_dist_06":"st4kbXM2MUVzTGloxEGGCC7l","st_dist_07":"kauccRicctp2RmjNlDju0Uoa","st_dist_08":"Pt4ZHubU9DGsCM7wUSfHh3an","st_dist_09":"6Fuia1Qfxqk4ziJlEYMoa3QI","st_dist_10":"rykvkhTNLEVaEP40PhPitdOH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FpqN6vGFXPkbJbOwOMBvMZlv0eYNEwTtV5lFxyBfvU65l34c2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":353,"st_w_id":1,"st_quantity":93,"st_dist_01":"TKsm8Ex99wGEnVpbkoBxyskY","st_dist_02":"47zb66s9JRXsYg3LlC3wUC2u","st_dist_03":"lOgyaqzvstLQL7YRbvYiEIOX","st_dist_04":"3kSAFCVldV3my7xpWGhRYAWg","st_dist_05":"hPBLxm0oPdngirCJXAnNkAC0","st_dist_06":"zOUB7Ytl8X0kYzJgYSg6IskJ","st_dist_07":"OMZXnVJlKtfqhKT8dPyfTN6u","st_dist_08":"5gMt6AKFHC5JMm3VBHdpAsnq","st_dist_09":"O6if0IbjbslDTqQvLz0lQ7bW","st_dist_10":"fyOOzPnwx9M0j5GAjTOyJOpx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qXxEq9originalqZaemfGekzOvIP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":354,"st_w_id":1,"st_quantity":96,"st_dist_01":"4QzkPf0dFnjMnpUDH8ly9g8f","st_dist_02":"zuZxQZfja4j1hb9r27anmaDS","st_dist_03":"P1zPVc6L5hL1QGTrhbf8bWJ7","st_dist_04":"RF5O8U0Qti4ceCDLKOJDeRVu","st_dist_05":"cAzVJyt3B1caoLi0fgPMJ7ER","st_dist_06":"l4DyWBvZdh2b3Y7hA16adoZq","st_dist_07":"k9SB70POugceYwpTzBZf5xnt","st_dist_08":"iNblkkse44ftfF0DSyXGJOrL","st_dist_09":"wKhhMdUJnYgliRbDf1Gw5vsT","st_dist_10":"fpjuxG7Pcoa6VLhuPbvZ02rJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wmptHB5INM7OgW9HwYypJmtAL1Myr6ZHoXaQizX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":355,"st_w_id":1,"st_quantity":68,"st_dist_01":"m7szTw50dwL5TNcqajVgY3b6","st_dist_02":"tW9fBvxnVMcJAnyLf373YkUb","st_dist_03":"N8JbDwZ5T7DvsRELvHJ4AnC5","st_dist_04":"7EjwY516fE7thsURgLITfyb2","st_dist_05":"en2fP78xVMRmzcQG93TdgNAg","st_dist_06":"5ciwr28Do2CDuZYhkgK2MIEP","st_dist_07":"iKOGYY3Udk8WxvUresJopIoG","st_dist_08":"jy1GkL9MQTjPe9avABNqPOiv","st_dist_09":"ln9RKckwwlX0yh1DrYDCZTCJ","st_dist_10":"HIIVZCJ6LhmAomPX3bWyDq9I","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R5uotq9ZODKqHdkSc4WsVbjO2cA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":356,"st_w_id":1,"st_quantity":84,"st_dist_01":"JblXL13rzYGr4zBNJI1wlk6f","st_dist_02":"nsUpM8p52wuLcIrl9Xyn34DT","st_dist_03":"JwI9ACosQyJ13213MUoSCwCc","st_dist_04":"h6Pjg0CufOnIcEdwyHYFtajo","st_dist_05":"9ujiTtYNMnWuBoTrvwYD2sKq","st_dist_06":"3JmKaC7lZSc7icq5FCchklXe","st_dist_07":"pOSHLsJp0MhVRhDTXzjRmm1i","st_dist_08":"euEKYBRTu5rVe8lMQ27kU5RG","st_dist_09":"fkDVem3olFUMBmaWqnFeWdM2","st_dist_10":"6NOAyL5B8Xfju2K2HIuSdidb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BjS5VRvkBZ3NstPaNcar0d2jDbOsCoXWg9JCOHb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":357,"st_w_id":1,"st_quantity":100,"st_dist_01":"BviY3olRBKnp0BeuBSKzUW0i","st_dist_02":"1kiDjNcScrYqKDbK5GsoqCRq","st_dist_03":"FehyO1KXVwPRnAHwNCeVo7jt","st_dist_04":"vgCmW2pDMq9GfoXTmc6S3duI","st_dist_05":"SsTy1S0WwJkmUENo5WlGaHEY","st_dist_06":"J2BLs9Vhx4RBmd00MFk9YXaI","st_dist_07":"uMNnOHd2GuCz7JrAok65cs1g","st_dist_08":"nNLLRH22NTRxJXZ6snOL0fDh","st_dist_09":"u2oZ7m9yB9MTshdpVCt0F0BU","st_dist_10":"9qLR54l4BPfMtkhKA1My9ofw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Cr8XFoqXJo8mThIXLtLveQQGvGVnS369SPrbhYPJna1Kg2ut"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":358,"st_w_id":1,"st_quantity":31,"st_dist_01":"QRM887sbg0ErsfRMiHmJYmZt","st_dist_02":"gMAtIEBBjCSSPEw7jGPRusqe","st_dist_03":"juH2ZyZzSu02R29eLNLy5NEs","st_dist_04":"pspkPBqaijYKWJhY7idGJfZd","st_dist_05":"T52GhsROkmwQF1hJTZGO3Hmz","st_dist_06":"aQSNJJG9VbnPQaQqlPlgdNAX","st_dist_07":"bg7Wy2uOGTXUISpgh3zmWSwu","st_dist_08":"rDVonoBNf9X4l6uUDdohOt9U","st_dist_09":"URj3lOtqmB6P79fuXWdpUR3p","st_dist_10":"gJzHgz1Ky5jbWwVLHyssi5YL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0mV4tQMN6U1izxlSqKVhAyYL6Xn6BrsA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":359,"st_w_id":1,"st_quantity":72,"st_dist_01":"DnahcbnU6u2QpsJQpb7I5BT2","st_dist_02":"2J17VC1jt32eJrh5dNyi6jqm","st_dist_03":"52FkGiQCzSAruMuYR0v8NWhF","st_dist_04":"KJnHu0naKoNCjEA7wy5mMeqf","st_dist_05":"OIDhHUsYOny7BqrmpxT1z71X","st_dist_06":"AvgsLiDU9OQE3RQtnLYrQGmk","st_dist_07":"bygCDxluhNi020y2trH54vz8","st_dist_08":"ndMfZcq1m71u5xPClott2JwU","st_dist_09":"SXpaOeJCoXpvZulV7trS8E7s","st_dist_10":"KEEj25XfxVgVoNKDztiQOGoQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xYBCtPT6fGXmtIq93J2as5twHzPXjN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":360,"st_w_id":1,"st_quantity":12,"st_dist_01":"h35oXTKPsEcoYHDvQVyYZzYV","st_dist_02":"GCsfrLaTF1GLAzOR7VCdQ5N5","st_dist_03":"tldmSOUtphOnZ3UjhZoLuC5k","st_dist_04":"wA4P1LLyweLXgBfDwdIvI3iG","st_dist_05":"DDTEMu2jd3IntTTGkb1JnhES","st_dist_06":"lTFGtDIyvIy5Cv2ums1vhSel","st_dist_07":"RY2tvZqfMDPT6qjeZX8R5m73","st_dist_08":"sC4c6h6SN8oooHPSg1HoBT66","st_dist_09":"OSmVHwS44lKYt29deizjdFPT","st_dist_10":"syllquNe4OEuDAavngfDmjOR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0ttGOYBQkgp2j1kVQG3avJUzdpE0Vsif8UmvlhRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":361,"st_w_id":1,"st_quantity":17,"st_dist_01":"t1h6zSBzmItAUyx8hqgcyBXN","st_dist_02":"jkvzLEj21HV7yqeao7h4qGML","st_dist_03":"IFa6uUksVlJTU9dQ65AxuRBZ","st_dist_04":"0RUdKFE74qrPfu8nL2emAuaQ","st_dist_05":"oalJvQ33HM3B8dL1CniBVsuF","st_dist_06":"dvpcAcEF2eq82LlymxxowmwB","st_dist_07":"N1ZgnlpF3A0oWqYjmwhGMt1T","st_dist_08":"sKvEvcxmAx3V9nWSip6I4MgK","st_dist_09":"mfzO6tT4xsgVD2Lg5EeebCfG","st_dist_10":"0cM3sLU8iBYjGFLrzLN5rnen","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wjIgagqaIDYCxrUEWuS1912LOnDnAjCzIL1tNYoFu6lgqgQ76"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":362,"st_w_id":1,"st_quantity":28,"st_dist_01":"qAs6yg7LPnzUAmeRkVNaBHn2","st_dist_02":"oWAYC6aQ4JAhyP80dghk1eDC","st_dist_03":"uVTgIE2t9vssWxTIr1nzb186","st_dist_04":"CxfDg1wONIz8s2KRqzivH4HV","st_dist_05":"rTgnEOOCfGqkgjmYzBjh0v9l","st_dist_06":"uAfRM1KeBkSb3IA7hjxyLd5k","st_dist_07":"GgO2I25pVWbKFUHb7wIZNhEG","st_dist_08":"adS47Dfde4J6Tdh2pHmdNX1l","st_dist_09":"SFWi8vnlUsKXWl5T8yLiWcio","st_dist_10":"vsJ5T4FZIG2jvVid5T3yEcqv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"thSt3ZEtvDLZ5zjoGE0ESYdDNSNNi9IWjzV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":363,"st_w_id":1,"st_quantity":17,"st_dist_01":"jPDECXyvoEBxOUcjqoJUCfWP","st_dist_02":"DOYRsqu0HFXirC0boQTIQig0","st_dist_03":"hRZOZCfR7uhtXxwAP74gGlFm","st_dist_04":"Vy0hJem2PoyTqmGtvZAjD240","st_dist_05":"zbTXUbyj8XTSTdU623xAg5w3","st_dist_06":"0ero3RUIPNa2OrvoUN8eZLP8","st_dist_07":"v4ktg4SHq8H5bOJtog6GXT4r","st_dist_08":"9bqwfbpa8cNC7ho1RteTPexC","st_dist_09":"zfdymY1X09C1RrtRna4RYox6","st_dist_10":"1RDYhQRoqpVBGIMUbOtVNd0k","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ce9lpOjUXUj5bUIeIrWdVN7DOoLh1Pn855nWZofU2i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":364,"st_w_id":1,"st_quantity":42,"st_dist_01":"R5uiQVkBlPzMtVqMf0aFPLps","st_dist_02":"5P1MFT85jF7ypTy4NtFrKSBk","st_dist_03":"Jbf2UYR9LcKyZb49NFt2ApBi","st_dist_04":"lUMQWAVAxi38fmp3B4NvlEzk","st_dist_05":"uxwLISa0V6y4MfxxAKXzEAEg","st_dist_06":"Vdl6zkgWCJoe6TQJbOScDuQ3","st_dist_07":"RodivfrVwVtnNu96c1za2QeQ","st_dist_08":"gM0eKrAb344FDcQR9kxiBHBe","st_dist_09":"2GkStwrKGweFnYJp3ZQauG9A","st_dist_10":"MvRZ4Vv8kLzVzW6anHrVS29U","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uYVGHHWjdkDYcMboD6eDu5yWhGme68d23CVKHzlCy5xPcFgzb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":365,"st_w_id":1,"st_quantity":84,"st_dist_01":"rppJbNcPzzM9duaBLVhGnxeq","st_dist_02":"poNPjijwebbXslE5epX3QK3U","st_dist_03":"0gS4vPOz2B1oTz7zJmI2gDyB","st_dist_04":"HBjN3SR9aCENADZM7bySwVHu","st_dist_05":"sngCRanFojO3hCjgiYg1vXFX","st_dist_06":"0F1vT5rpiJRGO66D4uztWscP","st_dist_07":"LGkp3Ki92CWlt5gPPuTpec78","st_dist_08":"3kY3HjA7O8IufM6dOOKDME5j","st_dist_09":"rX08Tv0rOsudUXNT7RvEVaU4","st_dist_10":"y8fhXn10G5jhcTC033fT8DYP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PLwwaMxiNoyRWXRs9F3vZhRvyUywl4Abt2HwiPRBtQ9WqPk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":366,"st_w_id":1,"st_quantity":29,"st_dist_01":"ZZkI2gNa2B4LkilVMBce6y0W","st_dist_02":"7WDFGSNor06FWO8CeIKnEagl","st_dist_03":"w9kqUxfq5rzzuldC88SrwYvD","st_dist_04":"nhPZY1Ra4gXeCgdF55gk7Mjp","st_dist_05":"Q6InbDQig1tRmdHnr5Bve2nA","st_dist_06":"jI2Ub45xc3DlTILzmUNtMHgB","st_dist_07":"YS3zBeMNVKKp5XFRaTXALlaV","st_dist_08":"uQb8c8CyfazIErWoC4WYXHJt","st_dist_09":"VQIjAfLF1D9TRmTMMc0rQUg2","st_dist_10":"Sfva4tULQ2FkT0u2wTxjKgPX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"a4hy1ql7HtEoriginaleKVt7tpXV2bT6fn6e32zOO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":367,"st_w_id":1,"st_quantity":32,"st_dist_01":"SndxvZnfytNqaqJ0h0ft0Nu1","st_dist_02":"Znx7iaI2oTOoKPphfh1E40Oy","st_dist_03":"zYgD4He4jU8DQGcUx8alOZp7","st_dist_04":"9Y3dgqrhPdujkIXEuhPsjSJp","st_dist_05":"nYpRv2ZRAHuorVKW2bUX8kP7","st_dist_06":"zaL68hUDWLwWlPoWEZFjxFQh","st_dist_07":"5FoMUBz1yKBWXrXQ1nz7ksAK","st_dist_08":"WESXVrv0hYg8mdPpOc1Eoq9l","st_dist_09":"sxfo4nrK4dBcV5VdvgfNFkzx","st_dist_10":"7GcrckOfklegH89UMq0iZGH5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"z7lq5DwIiwBk1cfZrOWCqg1MARnR5v40uLFQ59MQ0w5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":368,"st_w_id":1,"st_quantity":31,"st_dist_01":"Yk9eRlUVP44ivXSgi1zJ2jSR","st_dist_02":"0AHtKqhJqoWul44SMYLAkYEA","st_dist_03":"MfIE6XKTbb7Ruwos39aw2XkL","st_dist_04":"Rve6yzUMBUPooCrHd4fDHRL5","st_dist_05":"Z0rvU6p9lI0mLbQD55e9efWF","st_dist_06":"9AQhl0BXSMWE7mPNRi1YF1gF","st_dist_07":"nGRgNHScIcPBr85pNVmekYaD","st_dist_08":"WTsj7MyWhc5DhD4GOanDxkEa","st_dist_09":"XK1Ahz1grAEnMfGd8veY9mQ2","st_dist_10":"iFIa3pWbJ2xg1vqBjASXq0u4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1nDS8eGOXdwmwXV3GcoaNpvn8pPmLwn6ZzmM9hwUQVuDKBIO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":369,"st_w_id":1,"st_quantity":100,"st_dist_01":"2SeVIfyB8HM23xCmtBRT9dCv","st_dist_02":"wI2PvKxY3pZ4ChMMjQxRh9To","st_dist_03":"Hm5KEVXLUY1SfKLwM4648y47","st_dist_04":"q9eKGLRq0qn6tJgjR7DJ00PO","st_dist_05":"IrgyNQHFknGRjlY75UmkUkH0","st_dist_06":"3C2AVlPGPeNadCy9dLM9t1nL","st_dist_07":"ncJZZktC1slRTLanFj2hpFjT","st_dist_08":"Ania7cEyBViB2WbjyiLVX1xQ","st_dist_09":"TEnOFGHSG2BM3XzYXYFvTgFh","st_dist_10":"g5jnFJA6IkcwtbD090U5sSoL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UfyXvPl6originalxyR8zrWXiNIKRCjnlcUMZf45"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":370,"st_w_id":1,"st_quantity":30,"st_dist_01":"4U7jj862rhXSyymflghTL5h1","st_dist_02":"AKvzo0EnU1o4uNTfTW76Ofzr","st_dist_03":"6ZNAewPMWeuUITYFePB0EOXY","st_dist_04":"Z1vrVBJqI6zBsYbQOMjv9UfH","st_dist_05":"fh5SWJ81J2nXRssG76ddz7ZH","st_dist_06":"WvdERNchwS2imyLhB9hew9Ae","st_dist_07":"xJ7pjQIIuMu9vEUsphbHMapB","st_dist_08":"jtctAfJlvkll0AfgvEBluZpd","st_dist_09":"ukB2vtsv0yofa2Afd4MxQ6pz","st_dist_10":"QSTMeYqtTSdge2ro3VJsH3XL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KQyR4mvWO86H145c5gHxBC4Qi2M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":371,"st_w_id":1,"st_quantity":47,"st_dist_01":"6bgAumcMvBqsXCTec7T4HSnr","st_dist_02":"NeWtlLCm6W6ulh3Tu4eGkeOq","st_dist_03":"gvu0B7O6FGWIxjI2B4Prz8mp","st_dist_04":"Q8iVBifCUSqUxH9xzx2qAi1j","st_dist_05":"nnci5ScCWTKJjHMYF7u5xQ4Y","st_dist_06":"XjeApuj1FyuP5vS6zl44FoVd","st_dist_07":"4dsEJHmoTo7ChLtHR8bMNyjv","st_dist_08":"KrY9gdPbYrNnQLp5jwawenEo","st_dist_09":"rl7OyPGKS5lvLAtEBoMFhTam","st_dist_10":"kVbICK7KNGjcoInFVDdjSELf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"23RSaLDabdz673pbpJaBWaSXWDVWlB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":372,"st_w_id":1,"st_quantity":44,"st_dist_01":"CeSaS6M2f5DSCRS3YJfwmxW5","st_dist_02":"bbL5JbtRV89aiK6h9fsEe8pi","st_dist_03":"5ht3zZxMPXD7X0LlFzaTNfPQ","st_dist_04":"LWq2gFYf3Vac6Xg4bOui4Irp","st_dist_05":"vDWUoW9s0S0Wzrj58NZHIlvl","st_dist_06":"xyR88iubrpwCLNxhRo1KgXH5","st_dist_07":"6iLRF4IgogqPio2fcrbTnN7C","st_dist_08":"v29QA39xGvGCd1gAwxxkD3lZ","st_dist_09":"bRnRlOYGWuFazKvqXev9kgxr","st_dist_10":"N9PPFVL1VlEkYcHD5tQkaRPn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NN4yOYxwgi746firUyRuUG4ZVGr1eFbZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":373,"st_w_id":1,"st_quantity":75,"st_dist_01":"gKIEc4JjGXGtyyCuXEBX5iSv","st_dist_02":"WYVm7ddEb4WHW9FAFIHX2VDi","st_dist_03":"OWFfo9gfewuZS5zIdZ2yGOlF","st_dist_04":"8Y26eBQJzQrP4BGHesqzDMNg","st_dist_05":"p2CD6N08uyQOyLfEtY8vj0Gk","st_dist_06":"whmCDTpFLClSEIeFVmk7jUvH","st_dist_07":"CyQjiwP90iTuxxHhgs8dt3pr","st_dist_08":"36yUI1jRgQO3wtbstBDIkpa7","st_dist_09":"8rhjdpM5aUuupgzoVyGfqO3r","st_dist_10":"85MtXZgOZWF630R7YpeoXmau","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PdmllHmvmNQOk91UrRtq3cgArWECAvQnJTUJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":374,"st_w_id":1,"st_quantity":52,"st_dist_01":"RhbS71Pq5AfhVKorKSEa6Img","st_dist_02":"Oj7nSEDWwTQuFZDzrbgT7iKj","st_dist_03":"ynFCL0iBpk3crDbfYGXHaKuT","st_dist_04":"WxrWf4SpU42kX4lovEtsJmIo","st_dist_05":"RU3hUCPj5Yez63iW1MhpmOyC","st_dist_06":"w6l3qrCj0LXMVmsSj7dtm1tn","st_dist_07":"eWBwZaJci91s8JEuPsaPIDdv","st_dist_08":"OZJGZxRK1HwCcz6FZwuxjS2I","st_dist_09":"sdQhMhZYdDwglUuMyPEtNpKJ","st_dist_10":"OqH2LwAucmLe8ziQ6CMUiRZV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DBLQfPeuKY21VbWICUoQGFZmj41ZDVwX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":375,"st_w_id":1,"st_quantity":97,"st_dist_01":"ldU1z1AHDPEDzRXJVJJXJ3DU","st_dist_02":"GV9iI9xsOjIY7nHdtMXZwZiS","st_dist_03":"udzxh6svbnjY50LdqOa95XcL","st_dist_04":"lwG9OcO3Pl8jRwbf4Njzkt5Z","st_dist_05":"M5q99J5JTdP0gzQxgEgtFmC6","st_dist_06":"gO75WxPIIwoa5HyPVDzLtfkL","st_dist_07":"zurLWFeQm7mqWg723OLq5g6n","st_dist_08":"p4VJTIwA0AGzyKOUaReT9HrB","st_dist_09":"6E7BaBTnJXZaNbfmeNUgN1xW","st_dist_10":"hq6AAQq2o0QE2axtchiovEVw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NYI8IHoCQOtyAwvGx89VRn3zHd6q8mTzvAZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":376,"st_w_id":1,"st_quantity":70,"st_dist_01":"1ziNnFILRfIQrEacjixRfvH3","st_dist_02":"u00ozkWUH02qwJuORezPRRXk","st_dist_03":"Gq0IT0HIzQj75p8pVHhZpivl","st_dist_04":"8Y2wms89fOVCqFjDSvz1UY4D","st_dist_05":"cHnswPaullQIFc26psD347s3","st_dist_06":"Zedu7Ed2qZL4lJHXOnl9lFqx","st_dist_07":"aFRBRFQ62VlYzjP9RYsmxbXd","st_dist_08":"JWewvlF2a98wulmM7uHVnRJJ","st_dist_09":"1BQND2eCX6b1RyZZs6CHxXOP","st_dist_10":"cchTq1aSfXGiPzmobzV9QGup","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5eHoYX2inDBoTVrYJqScMJwJp5gITwuxCzMEo4kFLgt4Iip"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":377,"st_w_id":1,"st_quantity":98,"st_dist_01":"IoSNkvnn1zaZLI3Cm1UkjRf7","st_dist_02":"2ONGcDf0uGCv92wzy7uadUjZ","st_dist_03":"gRCzDiI7IG8guGYvx7jCeCAk","st_dist_04":"OuNdHwqaOinvGxtekZ2UuKfR","st_dist_05":"zbJ1Ac8d1rT8UiKK0mKAvsoz","st_dist_06":"kxtv4Xt7UDpupgpBzenfjv0Q","st_dist_07":"wkuTRqLr1vmtXcce7InbIBxr","st_dist_08":"nv1BHKo24o2ekHtikVXX80Yh","st_dist_09":"d1dpON6yPGBs863VSmVrybe8","st_dist_10":"BtLBUZ3wLsydNUPz6pY7ZbN6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t1y4vzpa0qviYZXhGDHNdDuxJexc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":378,"st_w_id":1,"st_quantity":40,"st_dist_01":"HgywdElWMT8oYjNI641kd0bN","st_dist_02":"YaDUjUw64NnDpmuDV6JvTYL8","st_dist_03":"w1nABhBP1xGPLJiJVhL8PHsG","st_dist_04":"CWMMQqjWtPUIjP0xsS0dNmNK","st_dist_05":"AXzKalKDHKEYeyvwfiSfZXCC","st_dist_06":"QuOTZSAYNckhEtP0ggQn1XEx","st_dist_07":"BCb0Z1o3FwfWtyPoYeezcdEE","st_dist_08":"6gIXuL0SBhZNvllm1mbG7uZg","st_dist_09":"vo19Po9Gdn8bDaM5rDEvQnPV","st_dist_10":"koGkL5uhqQekyrcKOmrJH6bp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1bt92iutJOYzHk4zpmNOdOTJ6b8V3kE1Hiak0d3K"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":379,"st_w_id":1,"st_quantity":62,"st_dist_01":"GwN401eoAIXnKYPxXDXSphml","st_dist_02":"Uw96PSmTLZS1UjDnnH8T3xOi","st_dist_03":"etwaqpU562c4FJ8ARdBphQGU","st_dist_04":"hfNvagavAPEEBCZ1TjufJdGu","st_dist_05":"Myl8Y4a6OqKRoFwcNjdTJYgF","st_dist_06":"59pXkNekwx8M5FJID3aiIQe7","st_dist_07":"9mJBzDIJDD6GlrU7qZyn6bH9","st_dist_08":"WQcx7lxNx1YyyZRZR4yDKklt","st_dist_09":"LYAmYIhS5sg0MSg5CMSCSc46","st_dist_10":"RbGClQgmX02uONLCt9xz3ck7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hllhFg1nu3GorWa7DGvqLAJujMFPYhiokrh6w26GWuIiPA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":380,"st_w_id":1,"st_quantity":26,"st_dist_01":"BLl7z6DkZQEA8LqtOWGPjFq7","st_dist_02":"CPA55g21CnJCezOXGa2ukds9","st_dist_03":"lhIPPiffMFFl98VLmp2McFGA","st_dist_04":"TBJGKLBOYdIK6sL4HzmuhGRL","st_dist_05":"lJr7LH9Pu2mxXfr0CBnCD1Cq","st_dist_06":"9H1W0to0VaFMZpEgyNI0waR4","st_dist_07":"F6FNONgOL7k8z6WxeHJAXRVL","st_dist_08":"T1heqDHagzVMMqyzKZ6TskU1","st_dist_09":"vpJdGQ4GchR6qBiDXzsslWAV","st_dist_10":"N6wMRryQWt5MfWSk0piIIGyw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UvEkwlkAkUU1Qk43Zd7xeYxkRgT1ipAKOg3c1C0lJFZvni"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":381,"st_w_id":1,"st_quantity":27,"st_dist_01":"TRESsAQmAiyXPX7k9ROZHBdw","st_dist_02":"3yyXSsLQ0fTIAysZopuAojMF","st_dist_03":"xK6KNdYudflJ2YPTmSVBZ5ZQ","st_dist_04":"XdqCInq1vIvKZTwKJxLaOr5v","st_dist_05":"bNrJzM0IfHsCiEJl0QbsmQXr","st_dist_06":"ZhsnlF4lqlVLKdaY4JHeFvOQ","st_dist_07":"q1jFBwIgjkQG0I1dOpxm7uUL","st_dist_08":"5n4QiUgVP2G55dp2JPraFZD5","st_dist_09":"6AGEFaavKcWUfzDjHrR0Z7C3","st_dist_10":"jJn1r1Cga1UzcKFV6AUTYXAE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RwdkXqHJgLIW4QOw1e2B9Wtdumq3jj6aF2cAImKo0d0emT6r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":382,"st_w_id":1,"st_quantity":79,"st_dist_01":"W0BPQ5MmfGT1EXgzLQte320a","st_dist_02":"BpOOotYSms5wye7gi1rZCh5F","st_dist_03":"4RecEByQ6FmnCZeoEoMZchjk","st_dist_04":"pVpfT0jrEdEQrj8DgWgzSHh5","st_dist_05":"v7ioxwihkQGsYxrJDCjIhzmB","st_dist_06":"yDXaD6dEBUZrZp5TP1ohvB3S","st_dist_07":"oMfSGebeq5PAEOFLam9bSrG6","st_dist_08":"Hz6QTQShRDn0H4d1Hv2gheVK","st_dist_09":"mvKVszZ0l1E67sQN4egTf86Q","st_dist_10":"C6SciSB0nBVU587lDJlqZPjq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lc7Fa1AzKJgoUw5BQkOoriginalteD0Xio"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":383,"st_w_id":1,"st_quantity":93,"st_dist_01":"yCPnpSvSrF9zoRLZJdcyh5Qx","st_dist_02":"tOEWKROVpdT9fwEk7ylBo1ou","st_dist_03":"VY4fQoPbcCoWoaTlVv98MXxD","st_dist_04":"tRj82cvvHJvuH5dV7V5qst4R","st_dist_05":"r60ZUUqruD2Tj2u3jaEI63iU","st_dist_06":"f0BNVVWppHmppT8ty2iJwrKT","st_dist_07":"fGdYR3Motq8Bd8TZXRw8Le94","st_dist_08":"YueVM8w8jO56AyzDTqOjy7Ix","st_dist_09":"9m0hmu4yaPeW9DiiiooQwY3m","st_dist_10":"DRoXu1THQ9LCO5NbMtR1ou0R","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eRGtlmkDU5k4vzipU9ofa5Zm6LoB4gaK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":384,"st_w_id":1,"st_quantity":95,"st_dist_01":"VQoCgSdF6saR6wFKa9G6YHGY","st_dist_02":"UGR8H3kKr8U1mRLn3ciCThyl","st_dist_03":"PF3KRAZVovaJfGavrlN5wVmj","st_dist_04":"dTOL9nFJUf2D4c0Mshq1myYG","st_dist_05":"8z4ypNWtVhooTP7yZNfhspJ6","st_dist_06":"ywkZPCScZN1n2O570eZt3UU0","st_dist_07":"sRPzqYbRwYtvetFGrODzRwgH","st_dist_08":"Rg2Nx3evxOhR2zdaVuTzc1zm","st_dist_09":"kMHfZ6AobXxFjOWUiwjz0Nsc","st_dist_10":"jfpYiwzlPBWVWnA1NvlHXsES","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4t6LY0W11QkWQ52IqmAzFE7TK68VdBgYg49E"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":385,"st_w_id":1,"st_quantity":25,"st_dist_01":"53fW4AA1ug7GuKambIJt59Xs","st_dist_02":"g5sgcvqAe81BicbP3IdOdMPq","st_dist_03":"PlyVMrDijm2VEqtbr5HEbgCN","st_dist_04":"6hXGg5OFujVHJfzAjgoJhOfS","st_dist_05":"ooaNfMOPcdqoefkXtdehWMoS","st_dist_06":"hjfeoRR39VfCzep3xLbi5b6l","st_dist_07":"A2uG8TB94NX0vOaEy6oPsqJd","st_dist_08":"pbrBY9kTTZk3Jpf1Ot3YTvbi","st_dist_09":"HOEQQbFJtSP5BF6v5kAHy5w8","st_dist_10":"9vOqQpBkLN53zFt1e5qWOFaY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gCNNkRA6zfoGYcpZubtoqiE0rYyhQlADOETzRM1q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":386,"st_w_id":1,"st_quantity":62,"st_dist_01":"WV1Z36JOVc2uqgyxCbAv0L4v","st_dist_02":"pSZWYtwOpZlQrdLEG4PkJQKC","st_dist_03":"WibNmrncioaw37KBzeFAdPLQ","st_dist_04":"rb1aefVgFFqJ7UCYnX3sjb3a","st_dist_05":"92ZXstIEckiTNgNxhtmjqP96","st_dist_06":"JrQC03pTX48ZyRI7ZzzH8fc1","st_dist_07":"X79aws0tTP3bRVauiRy8o81i","st_dist_08":"UxClOIBdtsfaLQMYi0dR1JAK","st_dist_09":"i8WtOu1HdyOnvtPpR5fHKASz","st_dist_10":"SqNRfxBLsZSyLoVpKjy7mboF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"unerUxSgFcPHvMM1UX9stjFqq2TkaWpuWnWA7wkcmhGl2zJwi3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":387,"st_w_id":1,"st_quantity":62,"st_dist_01":"lNAx9bd5495phtcBniVZuYoQ","st_dist_02":"CAQ5Z8M3GXmwvVJflQcbkH7w","st_dist_03":"s7QB0bI2CbGYOVsbp6CJhJP2","st_dist_04":"oq2Y3Zcq36XNsezawe2qCMs2","st_dist_05":"na27uAqRRgkk79VQ5F8j5RHv","st_dist_06":"mTYKYFQOTzPGjgNXkBRbVw5x","st_dist_07":"LwRbMv8H7rYvVSfmufiiiDS5","st_dist_08":"GYWCnMGMysjol2mNaUwv1DEY","st_dist_09":"2QIyzXBH53Vt8vrKG5SBFzza","st_dist_10":"yOU0gsW6Wv4caaXCDcxG3Kcs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8Jd6I7RvsGYIGurT75oqu5MJVjmMG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":388,"st_w_id":1,"st_quantity":63,"st_dist_01":"ODJIlZ35RJiIYqrQ0TkC3PrV","st_dist_02":"BA6dl3TMzna0GCqY0EJ54uvo","st_dist_03":"qtDy22HHQHVlfu88aO2sf0B7","st_dist_04":"ZYkB0Wp98XhVAOZtmKFDbU1Z","st_dist_05":"eNjRVlYp9rIRz324rt5a6UNl","st_dist_06":"gVkczttWIj63BNr0jzswGJPB","st_dist_07":"r7GedjK5J4mNBLijIEfIbaPN","st_dist_08":"N0BP49ax12VpW8DiF7MNzrZ4","st_dist_09":"gytryqZOyc2B2nNdHESoE4l8","st_dist_10":"FIXbfnorivNtAdcV1QcjCGMi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qbDPlduNwkLaCwdUkrgNSTUyRPGb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":389,"st_w_id":1,"st_quantity":37,"st_dist_01":"slsYI7feFhZxFhuR2oxbhSMy","st_dist_02":"2v7y0orPYgEWjfsJJBiDYViK","st_dist_03":"hXkwUi1qRuAajfFNvKqWyojr","st_dist_04":"F4pRnAEn4KZRDcgQEEqhaBoH","st_dist_05":"0zpRQdlYAF5TTRSu8IRmJpjA","st_dist_06":"SNXAFFefuX4pBpwrwsLiFbcq","st_dist_07":"08GQU9jwZPH15p3Yc7EuYRCP","st_dist_08":"L2roDgp6crH032WX2hhjvbGz","st_dist_09":"Ypa08yJaFxGORsMiGjQbYTlz","st_dist_10":"FaTEtwOgsCcLzPirUCW0isWs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AJ07aE0wF5RJ07Yi9Shb4PDjxHg3PU65kyv8z0ALDJ4yfZoYLW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":390,"st_w_id":1,"st_quantity":61,"st_dist_01":"cZBR1w9m344x2s3tC5buZPRi","st_dist_02":"EAjNTgt9MSvbPksRpugmZ3Iv","st_dist_03":"Tkoy6nzObVxbEqq5SLKPgoju","st_dist_04":"ruF529Qi03QRxNzVtQHWXmkt","st_dist_05":"ukoGeBT150ZHJz2f3V5xDSyT","st_dist_06":"h8btQGRVaoaoNxTe9G8adI2g","st_dist_07":"0JKqXJy63adyNSs2NEoWS1PK","st_dist_08":"GtzFqNiJjxqgdYQrNaS1FgVP","st_dist_09":"YfL4fW64tuuftZdosnywlAiV","st_dist_10":"Qsx9cVFYlaVK5gLlVN524DDM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wzU9Pdvoh6Q3g3MeIBVOiE5GDx2myfoSCuxlZF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":391,"st_w_id":1,"st_quantity":67,"st_dist_01":"8nKp8zExiGvRYUhXoR13227P","st_dist_02":"rEQkQxWhk2Xd31Xxuq4cqu14","st_dist_03":"UE2HYExipWTCuAuCk4Kw8fu5","st_dist_04":"jLYZRL6xKXaZcnLbuRPqz3fP","st_dist_05":"kHpTfEwbtZOoSiF2eJcEdW5F","st_dist_06":"2NqWxot2QVvrw8EuBj5ilvWT","st_dist_07":"JCTLe9GShhbBOTCRweU4an5N","st_dist_08":"cG6HDBPtOOds6UU0REgkk7Np","st_dist_09":"Z8TwhGboEc6kMh6VjKMm18nv","st_dist_10":"SF96tM039sJBaOPcYau9S3IM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RmBLckcJPIToC9cWl9l7AKNaWJxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":392,"st_w_id":1,"st_quantity":14,"st_dist_01":"hxdpbiyPB6zsDYF51P5qoqQp","st_dist_02":"v9jY8PjHQ1VjZ7nXELMNcrZn","st_dist_03":"Rra2QgY9l28PGVSJycEeEYl7","st_dist_04":"ktCy38grXNJhNdcyJSZBMfpM","st_dist_05":"mp3Exoo44l36i6NYbvFHfxfx","st_dist_06":"ffz2vq5yWQBJ6lBRdwPcVRk2","st_dist_07":"Oy4NJqJ58KfbTC43fRkbs0Hy","st_dist_08":"N24oowBddkG1NVgaH5VWBEjv","st_dist_09":"4vIZlCDfk8Af5Hnw8AxPrVUt","st_dist_10":"81lHgiGhn0r6quSCYgnSAEfp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zxE6Xd6WJu0w7x4I8Wobs15pyiaP09NE864nfJX7qkGNQM0K"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":393,"st_w_id":1,"st_quantity":38,"st_dist_01":"3a7XbLx5yHEZZFOQflk93PQF","st_dist_02":"WJ7ARTTZLqCZtxUpz7Ot5ax3","st_dist_03":"LpM5bX3JNWDZfKLn4I74Z3aG","st_dist_04":"hH8zYuMWyTITScrMibZZTZlk","st_dist_05":"JXhSs77GBLv0BZ0FLdDJpl3r","st_dist_06":"Sx0yZquK4S4k2o0tt7fgeuUp","st_dist_07":"rYI5x8d2a5rrNnNiuzNZ8koh","st_dist_08":"yRBXXx0bAWNsUeuqwY4lkQEH","st_dist_09":"sUJ42DFArpSunb7xsMsDJ9V7","st_dist_10":"Orfe9l2NxFUQpBi9mgmMoABw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OTSABdeVMMoVyKgDXnQijzQu8WaPU7dG7FSSv2PQ2LAWE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":394,"st_w_id":1,"st_quantity":64,"st_dist_01":"S7XLOubLjbut1AnReYLeyavo","st_dist_02":"6bhIki6EnLFYVcZlkek1EWgm","st_dist_03":"f0DR0RKvxefCLfAfl2rJq0lu","st_dist_04":"sRaXbvnf9owwAdZTLvl7lWwK","st_dist_05":"da0EyOIQvrmnegIUEmizTKlL","st_dist_06":"YNyBIDfYjw8qYnkOilUSbDdS","st_dist_07":"UKage3duYxVgDdTGVQjMPavW","st_dist_08":"qB2N0YjsGngwSN2fVrrxVgKu","st_dist_09":"glEbaNA5twaoHoreCSC5HCRa","st_dist_10":"GsaoRiK23PWNirxLwFMDO5A4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EFd6fkt7dEp7kJFMAFOZdADOoj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":395,"st_w_id":1,"st_quantity":51,"st_dist_01":"n1IjAEu1Rh6c3LvBxIONbu6n","st_dist_02":"LVfShI5kVN2VMn5WzqiNcZQg","st_dist_03":"Vb7SKaoF9rPXLNy08yy3MikO","st_dist_04":"5eK74EZUWPQBJsJGaLGG61qP","st_dist_05":"l3G6RHtUiReeQMKfMqtjbsQu","st_dist_06":"f1zjfE1J6thbtrOUDpVqZCmy","st_dist_07":"nsNnhAKu4Mb9leLEVTysi7iN","st_dist_08":"EBcIxB0mKaqAQvK24sZIBGgK","st_dist_09":"YeuZ4hCRywm4ZHx1ZkbA5Bta","st_dist_10":"hA2xI8Ox5H82fPgbBeWyqAh0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0x7ks9BorBedaTWVz05CCCwR4l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":396,"st_w_id":1,"st_quantity":12,"st_dist_01":"974ASAN90605UbRTRvaGmjLn","st_dist_02":"iKRNgq4pY5Jp7Lj5nmXWdmJY","st_dist_03":"R1LFbzKPs6GJyfOnJqrx9hCn","st_dist_04":"Zisib5s5dsV1wsoyrW67XG39","st_dist_05":"OO4qG7IP4KJxLaZ24W4lQkSy","st_dist_06":"gxDLnNbex2sSYnILrkHwA0L6","st_dist_07":"3hvBHNHbci1ltn4KkTOrmu6t","st_dist_08":"ydokGAVKhOJCSpOIZRNe8f93","st_dist_09":"xDwkn2Y2k0C9816dM6CTbQLW","st_dist_10":"guGk5wzx8kNu0UoGQA0znfYC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SZQhQQbAN0WTGe1DPrW4NND8TkVdS8EseMTCGwIXbNU7Xjfq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":397,"st_w_id":1,"st_quantity":96,"st_dist_01":"CgeC3sx5WGPc9ONu0dWwP7gi","st_dist_02":"BXjFo0Z9ALzi0Pe1v3EL1keG","st_dist_03":"3dQCVYvYlJuQRSMRS2tjeAWg","st_dist_04":"Qcfsj8Z8S5Dumv3hcjxpanay","st_dist_05":"D4cb7YHArDUQZgt5tyAnqScp","st_dist_06":"Dwb0i5bhqy0lCUjzQEBmWdhk","st_dist_07":"GLaLCVYqoVN2PBtExrvsoYrG","st_dist_08":"QnVSHcsBnqsXKmHtuKWKVJBK","st_dist_09":"QqzIiUzjbkpLCOeICObkAwkn","st_dist_10":"nf7dwd0DtSh7jlkEG4gqzwNr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HpkHgIRVM3AOIiui2eM9tTMPFE6Sj0Eqcl3bgoZE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":398,"st_w_id":1,"st_quantity":22,"st_dist_01":"jPOewWoqKyROKCEnVMlEsXHG","st_dist_02":"LGXIcxzEJmieHsNRu8IJS8om","st_dist_03":"vDQRhLuq4zqdibsuHlt9n2J3","st_dist_04":"3lW35PQ2M6WWmzrzoWDEJxfy","st_dist_05":"PjZPeSXBlj1KTJJKz4Wf4Udn","st_dist_06":"rXPx6tyCs0kUGH8JveOkOsVj","st_dist_07":"Z9NnNBnIzIQat1ppUZTRNGJT","st_dist_08":"ckYp17bxvqvAiDRahoNDhvJO","st_dist_09":"US4Bh7WSHUPqGZNBUM7UWQKg","st_dist_10":"FK32RNxNIVk7RVP1ydkB6K97","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"q4VWFdBy154HQWuuU1oRx6zWZoG67k2OZTTWBe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":399,"st_w_id":1,"st_quantity":41,"st_dist_01":"DtJJlygW8ju33P8a6XPQHLlU","st_dist_02":"Gr7cuHgRb3cBlw3XvZwJZ3cN","st_dist_03":"K8CEXjBaQqxHCCuij7PkOhas","st_dist_04":"sWSwGztuBk18ct4YsrXldCUc","st_dist_05":"ZDaM5PVVpVaBOc0j9hMbXXtc","st_dist_06":"pjaoAtLjyFwiarhGsxfzqBIO","st_dist_07":"YEB4fU203kbhjfewHaFM9bcE","st_dist_08":"5PAI0lnI4Ok6XIvYjYx3wNtB","st_dist_09":"rbXOKNhM6vUUutNnQsiLUlXk","st_dist_10":"m14a2TBgjC2SgsItCdEyakwx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DzaNCisKjOXCxOXbhqpbjaJ2Jay1qQdyh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":400,"st_w_id":1,"st_quantity":17,"st_dist_01":"X95Piin2W6ZhuNyRsIeLzNt8","st_dist_02":"ti9KsTcIDNzmvMbw4UXrdowU","st_dist_03":"LT24oopGhhhSFFzsMBimMHy6","st_dist_04":"ECCwMPPG9qBKinS70kD4ccyp","st_dist_05":"Q0VEvhZnYnZbrbfWNzCizyna","st_dist_06":"sOTXTpeS7GvtCuIJI9vs7HTt","st_dist_07":"AdB7e7uLVQ6apDPEk3qsjrV8","st_dist_08":"XjGMI4mVLZz3ISd3wbGk89jB","st_dist_09":"krNFZAmEOUo0RWdXsWNSs83j","st_dist_10":"evCgmkoYaB1kd9l7MsO2H3aK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fkgOPnZfdNWxqqodFeaRzTK2fThFcWRP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":401,"st_w_id":1,"st_quantity":41,"st_dist_01":"v64T3NdEgy1n8pJFZm58Vgt6","st_dist_02":"k5xPfPBJovhJxXndoKIGuHaR","st_dist_03":"PQPLolGmRV5zwbhopINdshLd","st_dist_04":"yAHH9TN6u7QFm7epeR8qW1C3","st_dist_05":"GaHlqUaOONMu3pjggOpIGbnk","st_dist_06":"qm0MKXxIUBVT6ZiXyr9iONMi","st_dist_07":"N7hoBprHEbbvHgSJUWsyOzeO","st_dist_08":"j6M5syQuDWja9xW82tGdfQ5o","st_dist_09":"SogxBvsqNbJAblMQdi62Eu6K","st_dist_10":"EsHab3S5NHUAWnwmn7EGtPyz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XLrSSgJpSXREEatCp1Rb6sWQpBTZWRA8hk0tMjwHhpNkyA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":402,"st_w_id":1,"st_quantity":80,"st_dist_01":"moKVBBcjiGtZ8CL7N00AyrDW","st_dist_02":"rXVLgCAyfQCRnGSe3WtrjEli","st_dist_03":"4zZlEvuqaYxRYL5v45FwyJjk","st_dist_04":"Nvscrm9SoSltXjHgj4Ld2PMg","st_dist_05":"RZB0KAuJvjILOYclE7YwjEw0","st_dist_06":"G3izw8XNW1EYP7IS3DLbDpQa","st_dist_07":"I4dbG2MR0PIPiPOtTMfCt32p","st_dist_08":"X4ecym5cg8GMKkrDcOZ7TNMG","st_dist_09":"8BlD5hygRSKV9BlTZO1bSdBY","st_dist_10":"8Ek12XmBBPW2y5za8TzEIu7Z","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tqUzOAVpFMDASm17cwsAaAU0xVLaskAHzoZXvVzSVfozKtSz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":403,"st_w_id":1,"st_quantity":62,"st_dist_01":"pY92ouThSc3DdQ2q9YTUGobh","st_dist_02":"jt6yIwGgfQMLunR5JGqCioY3","st_dist_03":"TjYkzSFWI9Ds64gbdqvhwIge","st_dist_04":"mU1EbCkulG9z96RcMQU8IQ0A","st_dist_05":"v38wtdyx2HS3EpUPfXZKgVj0","st_dist_06":"QCS3t3CFg07QUE4TMUnodKX2","st_dist_07":"o8KL9oCPhfPdiHRSFV6PVgdF","st_dist_08":"VXX5kGsNEezl7H4I7P3IZaIZ","st_dist_09":"xmwMDfYwuv4pmUDwE8ObF8NX","st_dist_10":"1fIRi3whnOdfU6dJ7h4eVesC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4zsh5IlAmwZzOVLKjuSfGQopx1A2wG1l74Axs4VCS3mm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":404,"st_w_id":1,"st_quantity":35,"st_dist_01":"2tWZVfhKewtqu3yqmB8XcuAO","st_dist_02":"Kbmm2o2UcFQVD42SweTLyLVR","st_dist_03":"j7ardR9wvk75fhGfsGYzP45g","st_dist_04":"FZPkjqH0AAeHCUVMdbCqww1v","st_dist_05":"5RJBXnIAAnwdhXTFO6vpfkTE","st_dist_06":"rSOlZh17gu3snOLG8qQERJt1","st_dist_07":"3sfYG7uWKidGOw763qhoYgP5","st_dist_08":"YP7mfktBySgqYDctP6zbsxmb","st_dist_09":"CVvUXOLuUMu56W6Ww1T0xGiN","st_dist_10":"kJSUEnXZqTR9MvBUtiuX12xL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1jvUWYIvDK9WmHRfIejTVEQsE1Aqg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":405,"st_w_id":1,"st_quantity":64,"st_dist_01":"5Xs6HRoJtnozbEntadRaRU8S","st_dist_02":"4EqVHE8JBy0LM1m7JZSLvYCP","st_dist_03":"GUJGVVqE5RoTDNEtmncANSOb","st_dist_04":"HNm03qIM4uS9QqjPb6h1UFOX","st_dist_05":"c1ia9PMGk9zgYtbwdL9kYkXu","st_dist_06":"f5FzBvDPU1wZbe4vJ4w5cLrw","st_dist_07":"DNClxbJk3DXUaebNQEJ24PIM","st_dist_08":"fctGyei7Je0zcCl1BYYFI8ya","st_dist_09":"8gRdq2ac1SaC2lA2nVbbwP5A","st_dist_10":"hbdfaFEYgtvxrPWEFIFx34f5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jm9iaWz7cY6KGraGUqQtfHoriginal"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":406,"st_w_id":1,"st_quantity":85,"st_dist_01":"E9pC2DPjKBTfzqgmHjZjTkd1","st_dist_02":"L9TsIEAtOUMGtVvTvidsbNbZ","st_dist_03":"2yrq5BQPcqnt1pAj2idTdzws","st_dist_04":"r4bWAC94X2YpFdQeN43xfm4v","st_dist_05":"yxFpbS5fvHMtHFNLyRsWyubw","st_dist_06":"VWlDJLY5CNo1pgoEbcgPpXhZ","st_dist_07":"FrlGK3e6VjBYo9cH6Rt6SS7z","st_dist_08":"mlLFB0HKcNGavZtUOU1pu708","st_dist_09":"yF303Ue8u658GgXm3a2FPMzv","st_dist_10":"4jSwJAMoNTeMkRRZV3HmnQho","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Na0SBIidH98LI7PDe7k4TRnEPptUZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":407,"st_w_id":1,"st_quantity":16,"st_dist_01":"esETyXAB0eJfTK8WFpFcz0ld","st_dist_02":"xggOYZPzkoUH4FO64dl97bcT","st_dist_03":"3gMGBmzn1sEna8zRYBSICTUg","st_dist_04":"EHIYppeVNU9qjhFkuW9p2Cpp","st_dist_05":"2IJn8H1yQOFMZhLLSJcQpXGd","st_dist_06":"WWSafn33eFaefb0hndKNveCW","st_dist_07":"xjIAULBGA9YXj82bkla5W8hJ","st_dist_08":"MiNcMHAh7N4zz8tNP34IZIrd","st_dist_09":"c6OhlWqNtx586Sj1XgP4hB0K","st_dist_10":"PD3MoNNy8Yr9yovtMoUneRig","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8vFFksezqkfhFHL8QXHdxQRidFy2TTH5jen9QecQvR5qRpU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":408,"st_w_id":1,"st_quantity":74,"st_dist_01":"FJHBPB0fWEHI3mwFF8jjXIvc","st_dist_02":"Qkm4U6rR3SF0nZv2501wQYbk","st_dist_03":"4IzM1p3mG6YVJFIryVIiX54x","st_dist_04":"KYyG6cHr6xQgJ1KjPM2NeSSR","st_dist_05":"0p6aQ5qgYhJwHHsl6vA3rPnR","st_dist_06":"Ya2MPIUpflqKRzijZGBAVgbY","st_dist_07":"OdGpAE2WjEb1WoKD1IUMHR3f","st_dist_08":"bPkftZ97tpwV3dzupZvjneLr","st_dist_09":"7xEutARHauQvmnuIWGWgMilG","st_dist_10":"2tAXHRzloXKsYLbEaLTolRrN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3wYbQzo6AUYHqctVkCdT9wLYoFwkp4eyGtVgY3A0YpYrBK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":409,"st_w_id":1,"st_quantity":18,"st_dist_01":"ixto5NOtnKjbBaP6ppC81CoO","st_dist_02":"e47SVrNbpW7WiqAYSIA808rl","st_dist_03":"XgfSU8L3FF3SujktZN51QNYO","st_dist_04":"DyNvoPPHvAuykEYyKcMQ4j6e","st_dist_05":"y1iNpMi8ycTFzP2ToULhdUw4","st_dist_06":"EXwMzZDs4prNNlgzlZnlt1yd","st_dist_07":"sXNMKF0f2NGogLwQ1Y2aNO8K","st_dist_08":"75BZKBemKcBFaAhWr9g0ujAj","st_dist_09":"fgkpLxLR9BupH687pipFOSgM","st_dist_10":"bok2YzpnT9N8l6ikAGOdJ2Dw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"X7yddItYGMy8vIdxUtDlgWaeBhCsybA0rn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":410,"st_w_id":1,"st_quantity":80,"st_dist_01":"IG6nQUJvvwJAdNJzQgkSoyzd","st_dist_02":"D9RpwUhlKHWHM80hASV0LVRZ","st_dist_03":"gsWuZBbtFBlyJe78I5cqComC","st_dist_04":"YTbKheYE0lpzCsbwUYf69j1r","st_dist_05":"Xwp6WZH5Zto8i0eovDTAyuNu","st_dist_06":"V4EJhtSnlJRZ3rPkyNzBBNyL","st_dist_07":"g05IXK671ijMssGv0T6jc6r2","st_dist_08":"Se5H2dPVq1cYqdnweYVmy2PS","st_dist_09":"XGOaUcBgIdy1nW3w62ovggU8","st_dist_10":"qsGA74OOLbQAh43vuX5emAjo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OtWhchWztabEVfxp1wcSaab9K727Tv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":411,"st_w_id":1,"st_quantity":99,"st_dist_01":"cpGBp6pQkIJHDP08fCym9jOT","st_dist_02":"DlqFUEZSgV2Gd4M42HXdPNhu","st_dist_03":"s3LJ4DzPw2BK1gR638RbBFQc","st_dist_04":"kFdENZDDH0ycnTiiO14evZUm","st_dist_05":"Vw0abDRjun4z6xP52OZbuXa8","st_dist_06":"7CzSxYE3ovexzHr81Uxs2v5I","st_dist_07":"3VwvMucIdx6YXcvIeQgPU6Uu","st_dist_08":"t49NRy9OGdK5SIxmNx2TjFcQ","st_dist_09":"1ODlKCv3OAovZMUjyQbwBn1Z","st_dist_10":"t7FRF7vZ6CVhtiJyAd0ywfQh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SDn0t7z8F71GYtgtrHjcVPFimxcOW6DyZUCR831BdL5kUinB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":412,"st_w_id":1,"st_quantity":14,"st_dist_01":"GzWsvXXvteg4G9mawDs7iIbA","st_dist_02":"8rRnTIqnq9Nul77iPU8t3w7E","st_dist_03":"tINYZbcLWck756SF5cey0SzW","st_dist_04":"kxAy6QCbctaxo0EwYIYDRp8x","st_dist_05":"7eSfz3cZHJitlxWw253unlLk","st_dist_06":"lspewT4BC3cz4jzjJpPjbDXE","st_dist_07":"nyWsYGbTvcLVhh4aBBm4ULlJ","st_dist_08":"OXE3JYBZNHi5hZbUmGHZfeW3","st_dist_09":"Ts9Jv0Cci4O2L93Tuani4rgp","st_dist_10":"l5ScZDaTwm6hluPuwPI2DdWU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B4RQsJewkofyEKu6jTLg8kCCNjktdHHTUgSsxo6Ux0JF0e15k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":413,"st_w_id":1,"st_quantity":24,"st_dist_01":"adAvY92mRtvomSTZGMbWMZ3a","st_dist_02":"SRK4WgqnWaH5zjXk5aI3gwUO","st_dist_03":"qSNmRKPMABeTeThHSLn7L1wv","st_dist_04":"yPbJ1YpFu5b8Fo65V22ZZpGp","st_dist_05":"HuZOg0FuTEP0CuAr9yVn6hPe","st_dist_06":"YC26IsZ5LlymXp7d9J7Ns8iM","st_dist_07":"2w7NOpLaoi6PBtpSnzFQLc13","st_dist_08":"ttfR0B1QAENxue5irb5xU6iH","st_dist_09":"zHf8fOnRxWa2Q9HGbypNcdLD","st_dist_10":"rX4G8QOlSFketxPeXWUvjmOt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sD3VU6XbRuEZNeADhD8AdvCPEHDIbJAd2Jw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":414,"st_w_id":1,"st_quantity":39,"st_dist_01":"aTwfLEHxYYkTcaF3fFBXjtWr","st_dist_02":"GwI73h7DoR8UnJrdQKpYKm4x","st_dist_03":"cOyhQuBPHG6t12AW4ub2eRNU","st_dist_04":"FyEaazsJ75DHL9VuVKHcfQ6K","st_dist_05":"p3Ic1NMYvoxbuUvRdj7dR5Iz","st_dist_06":"eGEnlyXL9dSI4lgiIfJpDU9J","st_dist_07":"cLDeXjXN6t54v6EGaGdwnS0E","st_dist_08":"krcBpL8avSscqhsMrw8FrPFd","st_dist_09":"BVoBeSlCicNEtnDgaLEVIfXP","st_dist_10":"hzpqWh6Sq8myu1ccmOKKfSgx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ESF12nworiginal2xjZQZcDitnUnv1MhYb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":415,"st_w_id":1,"st_quantity":60,"st_dist_01":"5625RP4MufvhP193Gi7IeH00","st_dist_02":"kMowY79Q9futQIcN1ZchEZuT","st_dist_03":"tHDP9KFGqk9SUXwCkNfPBAtw","st_dist_04":"qH7GeO3alK9Vg3PH642eYEhv","st_dist_05":"rmAE6eaMb7dYc2gFL9jh5M7r","st_dist_06":"w8O0pB0UOI0gh3znKIw9GYsE","st_dist_07":"9BhtpU1q0rTwDQ4abN2HkTLI","st_dist_08":"sx9Qy8bXNtx0UdaL2QaNx3v9","st_dist_09":"8F6peOafMN0LZapFGJpw35NS","st_dist_10":"jFyYQLo3l0R5O8gmalZJ6U22","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sxJRlFAivWioriginalZ1oW5mq1BcdErkSJaWAieB74dewZR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":416,"st_w_id":1,"st_quantity":94,"st_dist_01":"sleZlq1484789VfwOevm4MFV","st_dist_02":"71lWtd33xq9KWGGyWI7suPT1","st_dist_03":"kTnBEf6BWjrpG2lnll6NtyHo","st_dist_04":"rY7XnVCqOEzd61fPLjUNPCsO","st_dist_05":"2A6AHNUNsH2qE8WsgdWjPKrW","st_dist_06":"YIqxj72MBiGChtOl4bpljMVf","st_dist_07":"xicv4PIjl275JB4xUmqd8nQZ","st_dist_08":"JSNwSeRFU4lNnZCixQrEpdgX","st_dist_09":"9D191oSn5T2TrBfNoh3fv2SQ","st_dist_10":"ksWzhA82accrqlqi4AMCI8DO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YgEMBtqjvgBuGzrEkKUkKGmY6oMbJokMGlTkKmixylx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":417,"st_w_id":1,"st_quantity":78,"st_dist_01":"FeYVLL2jBcf4uCrzgjJo3R8M","st_dist_02":"cwyndKfG2cwp66eAeuqdnZzb","st_dist_03":"gfOvKaeEJ8sIP9BxRWdsdw6E","st_dist_04":"CXyl8PfphA7aowrxkIeqIwtq","st_dist_05":"T3NI2JkwCt9FUHLzC3I7COUo","st_dist_06":"FykLsqnBbF28MndFpKpB5o1I","st_dist_07":"tDAISybepp4bJZS01BVenSpr","st_dist_08":"nxBeazM0lxShaG8MAMaxsrkp","st_dist_09":"UHVN8DcaWgSi8875XQTkEoQB","st_dist_10":"DhFacUZHZ54O50JA8PnZt3cS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MNBIunaanxbmA14a9uMKx4Glits2yvF0y7C1Msx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":418,"st_w_id":1,"st_quantity":37,"st_dist_01":"FO2Ru7iYyGcw0cpY55K6jjXU","st_dist_02":"mSzecyLnHR0GG58WGEmr0Fex","st_dist_03":"ji2suwdAz3zcWrnndaPsQEjQ","st_dist_04":"oMiKqPuLwnanMt1CEQdop7zA","st_dist_05":"i4bXIqizQuwrFGvJ0ZToY9B7","st_dist_06":"vxZIUQx332Go4v0NyHrZ7QAK","st_dist_07":"UZ8nBifzmDHMHQHMFHSuOu3K","st_dist_08":"2bbhISAJSzfCVBwUSjsT5oYo","st_dist_09":"1vJZQhSxq16aPZTpMetbf5Ac","st_dist_10":"gughUgztO8GVUhDfvg7UOG1G","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7HwnaoriginalkPMzcSclnEzycR4tNew"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":419,"st_w_id":1,"st_quantity":92,"st_dist_01":"ln9RYdB7djptqsSNinanPnaA","st_dist_02":"myAsL9FZB3lIJ89n7bi7iseF","st_dist_03":"FGiG287YbXdfTczUnSIN0OV0","st_dist_04":"pXdwYanj9vtF2g5EAfKaq5yr","st_dist_05":"OqwamMMqXlHxmZMqh1CkLxVu","st_dist_06":"dxh3MJnI2e4VsOABArtDjVnb","st_dist_07":"E1DgDAJbTS7x78AcVxoermud","st_dist_08":"M9JcPrX3ca8x2qj181SxTlig","st_dist_09":"NghrAIXXryyJccIWWrdpQdZ5","st_dist_10":"do4Z1zP8CEh8lxJjGpsmNs7B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rvFKBHLftlBkZGsbVukP8wxgilIqVEzGN2Om52"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":420,"st_w_id":1,"st_quantity":83,"st_dist_01":"g3Df6qfJVaGKD0Gf53uypjw5","st_dist_02":"KkqxZZ8VqsUqXRkSshiQlTo0","st_dist_03":"GLpXbIaUdF31fGHMoi7LBun8","st_dist_04":"c50QKCB0eFPBcIli2Pg4sw0X","st_dist_05":"8qXkL1qulClcnkoXzd5YdWZJ","st_dist_06":"drSIsg1lNlNpjhIGkWzebWGr","st_dist_07":"nb1k1Ko3Ds8fMwkgvGXUzOYV","st_dist_08":"Avig2DIVZTUea71TLrnhZIOq","st_dist_09":"ru2zot7XENS6M5uOej1DLSTC","st_dist_10":"AJYuA8HwaBUnNfuZMGeEiA53","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LyQj6ykUwDwf4MpWY02pvnGmztU1aDFdI25tqM4XApbNcyE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":421,"st_w_id":1,"st_quantity":26,"st_dist_01":"3fLZHQJyqk3mqY2OLDfnl9tE","st_dist_02":"ZQYaKZN5QUE0L1ylYVvgurxl","st_dist_03":"5HPAEVmLmISRCzlxcAv71MPV","st_dist_04":"7vWtRD5C8PohS88LVkYkNQVJ","st_dist_05":"tyhZcKo2rtsqVnlLNtwxtR4x","st_dist_06":"ALOTh1Rv1YKbfIvwSqSdOcqW","st_dist_07":"kBAChcLD829JKcWxOtqsvI5t","st_dist_08":"HyNYNmRRuch7G2OyYFrdJiCc","st_dist_09":"B44Rbn1mwRF2XUi512YgbsYQ","st_dist_10":"3bxRKs5TCAvYgPCFbIFK6puV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"k80mbl8gkXUyutTA108qL2mAU8kf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":422,"st_w_id":1,"st_quantity":23,"st_dist_01":"tsO3ngdsV6EL5b7xy0RGXYTp","st_dist_02":"WZhYTHZWT5d4ckxluqAEJUDC","st_dist_03":"ElriDXOJGXyaFYbTq38jp7O5","st_dist_04":"UnilYt8qL0eB4gTyKVsHRHZ3","st_dist_05":"2A6G2cvI0BqLgyKxxFDNPJS1","st_dist_06":"buLQLo6I7kxQ2DXwPiK55L9c","st_dist_07":"wUfGboZ2aIt6tlUBrKBuu53s","st_dist_08":"KbaGb5jkQlR0YPjiRhfgyjKl","st_dist_09":"edprtt8FVPHOl7kCbUR78JnG","st_dist_10":"GGs9NDIlhRzSbFtHv6PLDh2r","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NXSIvkvEgIwdSIz3oy7D3jfoWAstnRk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":423,"st_w_id":1,"st_quantity":45,"st_dist_01":"IImfR1ywrQVi8UqqTOzTz0yZ","st_dist_02":"uDTpoxkaW9nsywKAZl3yZqWO","st_dist_03":"om5qDDMUkPHEup5XdrC584RG","st_dist_04":"Pwb0kBIoWRgK4iueeMO2KRTw","st_dist_05":"KbhEM3CDn9Mt9JNny2uMDYH5","st_dist_06":"iBAGnoXCwn0T2HfGlFmCONkF","st_dist_07":"dsue3vE1GPWpKzjU7TIbEqQC","st_dist_08":"lsZSkRIUks2Q0zxP9hWm9QDs","st_dist_09":"Rf1DqsBQ2Tfocb0x4uL98P69","st_dist_10":"WCGwEy6NQOQRi7CxBBCRTKzE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nGXHBmpqaoriginalaDaIMDIrjv3QsbPM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":424,"st_w_id":1,"st_quantity":52,"st_dist_01":"WztJ7VtcvwWjCSBmjS2UNfKp","st_dist_02":"KGuUkE9vVfhRdzMBm4InCIYX","st_dist_03":"XNu6JhkuIQtdWtjupPq5asqg","st_dist_04":"ajyb52BEerOAxBk85gXAwRu8","st_dist_05":"QKsJAtqITWjrS3I5aoFE50oa","st_dist_06":"j6o9Lzoz09o1IDTiUT6eI2tp","st_dist_07":"XkSjLZMrIFMXLLC5H6qNSHxu","st_dist_08":"IoF49PjV54Bb7FG9sULDdla6","st_dist_09":"CHC2LMmy0O0E5QWEkudC1kdj","st_dist_10":"hU5vC68GKOsucR5YkaTGBhMJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NxSeSJtj5tKWyJ5v2bVOwri55lETfp5GscG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":425,"st_w_id":1,"st_quantity":69,"st_dist_01":"BUbAgUnJPzC28UnTmW5u2jNV","st_dist_02":"MPCAMP7T6cnVykQv7nXdZdNc","st_dist_03":"egzSmk18xHkVHS1GGQ0U5b94","st_dist_04":"jg952NjjszjEW3EgtFu4QLO7","st_dist_05":"s3USGdbDcgGQBPd2ah1yP30T","st_dist_06":"00vfk86gnKIzG4QqdYFoaMpR","st_dist_07":"ssW4rtd8EASzZEm6BdyfHVDw","st_dist_08":"1cXAjtU1UM7DCb8ljXxR19f5","st_dist_09":"2XGsl7J21UNifkRX8TXtjZ5G","st_dist_10":"EXwMrFQpRksIHeJOdUb8w1ba","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"USEA0tCEoDAHDtKFgCDOqMvSJ2PSFa4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":426,"st_w_id":1,"st_quantity":83,"st_dist_01":"2r9spTHkmA2M0l6oJquYePSA","st_dist_02":"6cnUY0wx3nYJnbtNThulnasb","st_dist_03":"bnr637rOE4MT36K5XRLzVWai","st_dist_04":"cvad47qqWAdbHvxWc1Q9Wh7x","st_dist_05":"yEP9WGJeDiMDLQf6fwv59B89","st_dist_06":"wY6qxoY8UXmaV2RhYqI5XIWv","st_dist_07":"pkNk03P73OXOqJLwzUUnFIT2","st_dist_08":"UOdf2IQvHzqNxBIia9eYuvYi","st_dist_09":"OV7hLwhqtvcCJSZbsUTyi3Ug","st_dist_10":"bBvddmJZmy6nL2pfWlYBQfBn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SlA5EbNpsNjHh5IUBHdCKLCG27hzELghMX1Y3fY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":427,"st_w_id":1,"st_quantity":51,"st_dist_01":"7GFkRNcZxyMRIDR383OhKwD3","st_dist_02":"0u2Y5BqAHjS8jdYnADNGbPFK","st_dist_03":"ZrMOPZ0VOKIK2K3q9MX29CQm","st_dist_04":"m6npMdtZ59Aw2NZ9NvZO6BYs","st_dist_05":"vqCpPw3tecHfvYRul73sS2V7","st_dist_06":"b6teYhM8QZTIGtxiu4ZhrpZn","st_dist_07":"VaP4qiZYHHyH4IxuvpXjy3Qi","st_dist_08":"f9E6saPKPPiaIol6xgWvy9ed","st_dist_09":"yJChqGhoEax8zNTF9xjTiOgg","st_dist_10":"mEyIA23m7ZnTqkI2TeBS5Adc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7dAh5Lp8RahXR0mRbu2xnbgMvkdrEgY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":428,"st_w_id":1,"st_quantity":18,"st_dist_01":"y9hGJXoEIVKXzfd3iWlS61by","st_dist_02":"AzlbjPrX9PukYzLq7Y16FktN","st_dist_03":"6G3BLAzIXn8yR2JPeK354DRg","st_dist_04":"plFhE3GF2bVkPDv6v1NnLfq9","st_dist_05":"N46hB2G4rELOVS2AiigvWQZf","st_dist_06":"BKIDyEOCEZUC6WpvcJ0lsidE","st_dist_07":"AKSWDWs40g2Q9BEEjKt7J5sD","st_dist_08":"Z1sy3Dy3Nl4oxoQOZbqH1g8t","st_dist_09":"cHOWBDlnvDkGbIrP7emIcjai","st_dist_10":"VNjnyuhDkdpwHeSYT4sylilL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"E9SBtyGIsE3GCWj6UY1WJ2MOa8VusgqNv7wPqFOg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":429,"st_w_id":1,"st_quantity":47,"st_dist_01":"kDbXPTS6VP8UI1j20HwHBJWp","st_dist_02":"bNJ99GcIvEdgXsWP1SSgdkye","st_dist_03":"32QzO2x11g1FBX7eB8WbxDrX","st_dist_04":"NXIYfivOQBYDXCjNBFpbKw63","st_dist_05":"s1tFv7DmKOf6gsACzy4vRueu","st_dist_06":"Ocakn0pvnW1hyeblNbEKhaZd","st_dist_07":"gRYaJNxWBLsJ1z8aw1RRGjgW","st_dist_08":"O9odyNLlRqKRoe2dctZLVeLA","st_dist_09":"nY1hV746D8dv9xhGG4yJFi4M","st_dist_10":"hKBaQvWf9SpWvu9wgzaPmFaT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JCcMjadeSt6eRfj8UhLgrB88QMPTdhH6hlGyw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":430,"st_w_id":1,"st_quantity":27,"st_dist_01":"Q8fDrTcXriSXwqGloA2CmXAQ","st_dist_02":"IH1hGDI9aHmEoAnCShQfkaXq","st_dist_03":"btHm1bHttYfKVoBN6zkwkbaN","st_dist_04":"u6PdGcBh68BVh7idXy8dBlN9","st_dist_05":"Bc77irBBxjgkSisLCEXfq0DT","st_dist_06":"ye04KgFvFit9VETgcwA1X9h3","st_dist_07":"YICJPHF02tgJuEKkkRyxrXqk","st_dist_08":"8m7B4aAODDQ53nRziGd4ba8w","st_dist_09":"Zrj5ysNi8jtKe3iTCu22qkJE","st_dist_10":"Z2viSTPPkEPzGb0XiQLhrxpf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ykN6JvnN7Og3LNhUHzH3i0zbUT30NYMBRtMdHiseig1nAOe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739237,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739237,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":431,"st_w_id":1,"st_quantity":14,"st_dist_01":"ZEGx1dAPU8yDUB9zImDGzBom","st_dist_02":"PVc7vb0b1PoeuQPDjqvQ55Vf","st_dist_03":"zTS9ZOBC43wtd8RDvAy0ZwWB","st_dist_04":"pXmKUpev0Zr42upnWRp7mNtl","st_dist_05":"l9FoAX8beNCaL5mR8H2toNAE","st_dist_06":"UHvn6bZFJoU8BpPjnYaUktPb","st_dist_07":"DOt0U6yelwE8mAEYCSLk2FyI","st_dist_08":"uDGPTbeaGn9ZwCRwO7FUkzl9","st_dist_09":"vZNjm8dz0FxEi67sG5jQjmoK","st_dist_10":"clgWcWxI8JllhPiB88Yejtqt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hfjZuUU2jU2LwAJOVaJc3OSjSNt22v3ywsQHaq41W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":432,"st_w_id":1,"st_quantity":19,"st_dist_01":"DKmhVOGWZ5HkmWgK287rKMGL","st_dist_02":"RBRDypr9x70kT6V6ARNmKSes","st_dist_03":"Lfy1qiqSfVIdb6BpVdEfibau","st_dist_04":"FBpd6o8kNshBM4Ohn6WlYSPr","st_dist_05":"smjoHjkKVXmwQbZGFL3XhKVR","st_dist_06":"xgHWwdtGLueAxJ6hUM2w0ITu","st_dist_07":"Lr3DOFMd8tWuxhbwBxkxKRKR","st_dist_08":"ar5lwqVpG5fMVhGDSfvA1thl","st_dist_09":"2SjYrIqAMFZ9pRAN68tdB4sM","st_dist_10":"yh9Xq3KKcpJJdySQoQaN1b8T","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pjtJfRNAxZ9yqGT7bo0ABFZDys5sXzW6S2ls0exXCpOg9t2I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":433,"st_w_id":1,"st_quantity":51,"st_dist_01":"i8vW91DzdCBl42j57kbq0dyO","st_dist_02":"7yzQP6TCh0mQjTknOkjkd3DN","st_dist_03":"7dybnotPelXxa9Cwa8BLXHfQ","st_dist_04":"aC8ykMekJ79Iq281F08FeZQh","st_dist_05":"t5FYLxcnFtHjIOY7bkjQksFS","st_dist_06":"MfC92cYza36OHiGjCrHrCzVn","st_dist_07":"E8WLQ5WJf6tWg2JHpK3YoPBJ","st_dist_08":"aSoeGvaU2WbrksVdFFIyetkg","st_dist_09":"m4Px47W4Pg6TWuRaCCeltOgx","st_dist_10":"9teoVX2x2kntSYqE5q0AHxNG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aZtzfGp845W34MOG7znKGilslMK2HrLZALUxNkTFIJlUkQdwL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":434,"st_w_id":1,"st_quantity":16,"st_dist_01":"01K2Q8NaPJiK8QnNSFbKLIMJ","st_dist_02":"iC57lU0kMmvXUHdt6jhz95Nf","st_dist_03":"WgveBYMRNsOXOJzTT3v8VbRQ","st_dist_04":"WDnUDlTuhe00M9I271yMaA8q","st_dist_05":"meHs8Jr4sinFM0d1HYTxjE5D","st_dist_06":"2jSDxdqt8KZjRZtHhxK6TdYq","st_dist_07":"CTdoYBPMBSaqBAh6gZmWfNvt","st_dist_08":"jUDWApKDmZ5NymhPCjIWR10i","st_dist_09":"q5ggIiHHnkMKAzyk73h5KClH","st_dist_10":"CelyTXK6K0XYpFNutcx0qutj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"u21HqesfCZBcZVR1AgcnONf0Y6Ww7KtsgJkPlbUj3EGl8IL6I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":435,"st_w_id":1,"st_quantity":81,"st_dist_01":"xIZm1qc6O3yPdBR9r2uF312H","st_dist_02":"pxyJKZ1LIa6hgw61zakgq9D0","st_dist_03":"NFGw7GUjlMT9N8yG7oVpv442","st_dist_04":"CB5thFQWIZb6Qz6pVROfomKr","st_dist_05":"l6WJHjj9rtACxw0570BWsPP0","st_dist_06":"f34hSwI0mEyGZgnEL4smBN3N","st_dist_07":"ak1MbUCn6ZtTe069LL850zEe","st_dist_08":"OfUzhrpZLuwtU7zW4ul8BnHh","st_dist_09":"fFKhUHWSIgQvyJx4uVBLPIMV","st_dist_10":"MZf2BNEuXsJK4iLYaxNYqmrB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FpYnkIDlVJzo9SUNAPXGf4soDEtPF6v2TXcwPfCingZhT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":436,"st_w_id":1,"st_quantity":71,"st_dist_01":"XTBmPlabhqJhTsAX3JOO0TZ8","st_dist_02":"F6YxuDj4dTfXjw7oa2FRJVDD","st_dist_03":"kmK2RXP7DG3yiAOtoakwWLhu","st_dist_04":"G5Epzi7YoQr8Y8JkDzJ6matJ","st_dist_05":"7QGX4zsUteTj8QfjEnYsF4SN","st_dist_06":"4KObUMHU1fvaiUxL85gN8x8y","st_dist_07":"gmP4PVmZ17kGdtJRndjSO2NR","st_dist_08":"UQigR6lqRVzEjm2ldLoY089h","st_dist_09":"d6Bt3JnPezB3rbBUArVdcv2S","st_dist_10":"WkbmnFGCXmv0LyaqNaDZhGYu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v3WeREiM3swaQobwV8pwwo3bthu5qIndJ4ZmRU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":437,"st_w_id":1,"st_quantity":100,"st_dist_01":"3G4MhaGuzd7IN1hDTWcGDYe4","st_dist_02":"nBbi9iSdwIZiqlNAbsC1MsX9","st_dist_03":"yb7LHtXILM6eHkyj2ohfxdWS","st_dist_04":"3LIeC7CauLSvy4UbOYp8Mos5","st_dist_05":"H70ctGGHqZF5NYi95Ik29I8v","st_dist_06":"yL1kQ831Uhpzy6nS9eiTgbYO","st_dist_07":"yzgIpEUy96hwcfjdkuNuHae3","st_dist_08":"ZyZXAtIksG6sRv5vBzQE7pNv","st_dist_09":"PE58uUwE10mvL4caVsxbxFre","st_dist_10":"WZCKugyHLnfKNvjwSLJP34IY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"H0I54FdIrK3Nhy43BPmglvscOnGqbd9zO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":438,"st_w_id":1,"st_quantity":95,"st_dist_01":"TgO0G2JRO3yeW28likaKOL5S","st_dist_02":"qEcnH6NKdbIW0pZw6ArHCE3T","st_dist_03":"2WiFnJzAXmcn32fHDVfuAAur","st_dist_04":"SsF4IbrEbVlkCXpCP63saz8s","st_dist_05":"RUMrsOrCDFfv1waLq0hbO2Bj","st_dist_06":"lDqJqNl6WiJybLlUXlsLGRNV","st_dist_07":"300PnXK8tSDvThH7i9RyxKSh","st_dist_08":"ZKBDnuFTsabLnsBaSxRCD0P3","st_dist_09":"puM2yQRc8RzG8KCLsQXWfhMW","st_dist_10":"kecFsA18E7JoXGTGDq5oMLf6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aWVoaNdT7ooHkZECCRTZgfCXZHFgq6S4T98UR5HcKZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":439,"st_w_id":1,"st_quantity":86,"st_dist_01":"2jauRvBuMtWc8IKLIABNTpC0","st_dist_02":"e47PcoQIn3sRnCy7viq9ybzy","st_dist_03":"Hhm0qwRtWbk7ktHE9q6e5TYa","st_dist_04":"tDWwNyCr3sqVlGMo3rmC7EId","st_dist_05":"zHSwzk4vDBG2lk6AdqmvIbMH","st_dist_06":"XfBPmgKmUWXZ7WaBByIZfJuM","st_dist_07":"2qrd1dB2Dy2AbUEPk9YfJe1V","st_dist_08":"xptHRNxXKJW4m1z5ftSEqPHf","st_dist_09":"xcli9xKW48sogliWYBtteyN8","st_dist_10":"A4kxRA3FW8LxfLPrHwvKgsWr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FWN40T6cg9uv38PVxPbfWsrR4YIw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":440,"st_w_id":1,"st_quantity":64,"st_dist_01":"CHIagyIp5KYzafBDQhTs3etY","st_dist_02":"Soi7puwWE8s8jQuwhkRdFv5t","st_dist_03":"fuUvMm1f3ywkzLZSBJA8gmFT","st_dist_04":"cD3UhTRttwEt6K9LZwqOlg0D","st_dist_05":"fz0lKUe3cDJ8beQqZ1JnoeH9","st_dist_06":"S3BFobSBkdx48gvFrugZuraZ","st_dist_07":"CBSBMW4iAxiDFo6ETohxG8FF","st_dist_08":"SKb0YTSH76odW642RGOSWFqn","st_dist_09":"yj6PuVmgg1lpCtbQkrbtr1hr","st_dist_10":"wPKYDB1SaxfetJPSCZc6slUU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vvorHnWNR7XmiQ7NUpiBaRDQrR7yA49n9EV0aQtiI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":441,"st_w_id":1,"st_quantity":38,"st_dist_01":"FQLp8Ve89zqG5PhEfVrzoZyk","st_dist_02":"OIsWxbns1sTx0SgpMSXdDLwS","st_dist_03":"TQMkTwRtz86v8Ty2l7WKNabF","st_dist_04":"8YelmzcupoPJMiS8s8WjmLu1","st_dist_05":"82tYJZ39ix1ZAkLF7rsvryAQ","st_dist_06":"wuRKs7aixf5rzirLczd2I0QT","st_dist_07":"Gpe8v9It1LllgtzE7aMyH3is","st_dist_08":"pwzuNLmQdnvzvuIE7tajBeuj","st_dist_09":"icSD1xWNDwhUhrSdLHvwjS4I","st_dist_10":"jHY0hzOTiU89qB5QNfE0y9vZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"D0kVvBq347qPxQlhkMJNARIWFXy7CizZHM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":442,"st_w_id":1,"st_quantity":74,"st_dist_01":"wSjcNUztkt3O76pAxsfPZaUj","st_dist_02":"OQcZHp848Guh0iS3n6QtS05H","st_dist_03":"mQHKoCjBR196p992V0cIc6IO","st_dist_04":"TWjRiK5hDsEKCRKHVlUwR1sv","st_dist_05":"NN5jY7eT3kRMfCQBEXOfmarD","st_dist_06":"WhN9UCxtVhaToYBUEHh1guMk","st_dist_07":"X0ybny8VlaU4BxneVBCe1fAB","st_dist_08":"HFu40q2WcdacjRmPbvE4OFcV","st_dist_09":"uACzov2r1xQVOMQZW5uCe5Uj","st_dist_10":"b6iGUsb6SiJqMP2KLcUf1mfa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9IZFsQgD795AgBoeEn28nzFZlnrh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":443,"st_w_id":1,"st_quantity":44,"st_dist_01":"VbNpOkKny0gRMwtUI6JtjicO","st_dist_02":"51tXb80mhT5vQiFy7ml5vkyr","st_dist_03":"0mwhtcUoJBzfhvQXaWcFfUar","st_dist_04":"pYWcllkgIWcrZQHSOpmcDhQT","st_dist_05":"63WmiIMKOUVeAo9ASycTPyPx","st_dist_06":"l0dJbZ3nZ9pB6jzKwPvjuPeo","st_dist_07":"t5EdvBPfYDmOUwHExo89AqOu","st_dist_08":"w0KLDgIS4EiP85DcJ1TjnokY","st_dist_09":"msNvlq0KZKXISMdXSPMMIkyp","st_dist_10":"oDjqPGuX3GgDYaRRLtQ6H66x","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7axG5YFCKQ7Vkzschnvj9HCgB117x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":444,"st_w_id":1,"st_quantity":24,"st_dist_01":"bFkV4tB0qh7cOBXGrHVn7Kq7","st_dist_02":"yig0RcXs5s6dTtKfMalSSkWU","st_dist_03":"qViDWViKRQcLGwSyagrwruu6","st_dist_04":"dnjbtRW8TCezf0qf0I32vSst","st_dist_05":"kfZyO2Jht4xhl9AZOLZaBij6","st_dist_06":"2IJSPLujnsh7MOrXbFZsB7rq","st_dist_07":"TjKuOBJaVetpzEvan98YXTUs","st_dist_08":"r3QS2gefpC93lwtELe3gGiNp","st_dist_09":"Yj11kzJ1STI3nhGYByTH149n","st_dist_10":"5bXZWLBQdSTQNt8KZU3IGqKj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nevBgV1B3s1wu3TXsRP90UQZABEQKEsDRzscDohZvKiU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":445,"st_w_id":1,"st_quantity":88,"st_dist_01":"vQYyq6zQxG1y4c3hejTayCSM","st_dist_02":"1bGilaroR9v1jqGFXFC9xfXU","st_dist_03":"VvHJ1b8hBOl5QBY5TMglG7KM","st_dist_04":"wbd2btPhF82TyFp7cYP6qrGX","st_dist_05":"LwVLE26v5LPoynsCYPrvxaWb","st_dist_06":"tdjsONNklRyFYTXm0qgbLyYL","st_dist_07":"9mpO0XylazVE9zneYB8fc613","st_dist_08":"zJX7yYP4qBmW3Jh4DB0hlBUi","st_dist_09":"oZjJxVJr6lZymngOiw7vVH0G","st_dist_10":"mOYAaVIotSiHnemf65aeaaX4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AcBkFuUqJs39DDxDxYlopKrPYaHSInyD3k11E"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":446,"st_w_id":1,"st_quantity":38,"st_dist_01":"r8TIzRoVqUWmkI4Awt67kk6A","st_dist_02":"I2TVCRaJrZlnTTOizAg1Dkul","st_dist_03":"3TPjR05kvFwaT7aPTTrkIE9e","st_dist_04":"gIzNRFfRSEjXswq0TZKRhwyn","st_dist_05":"HZD05XHHeTnJULCBp9Vzhrm9","st_dist_06":"uxE8hZHr8Tu8dgc044oVfaXN","st_dist_07":"hozMzRi7fa7J7QU9qocMHYKG","st_dist_08":"cDlnhCU7PuFB0k3iLEe9LY2H","st_dist_09":"MRo4KnVgcZo5369EkjcMoOh3","st_dist_10":"l9LVVW1ORNPRTLfNH6TvT1A6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0RbUNaC04mOzjNLQHgSvFWzuevQPtkTYa6usXXak"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":447,"st_w_id":1,"st_quantity":94,"st_dist_01":"bqATC3HqimzmAKbyInFlNJNu","st_dist_02":"xcb9ARNBAQVWQpMv2c7swtFg","st_dist_03":"89VE74cWiPZIlsdVLuBymrhf","st_dist_04":"p9rc4D6FgjZ0P6yhKxpoB98z","st_dist_05":"dgUWCsU6nMak49sCrVh9nGnW","st_dist_06":"foWaBnSTa88wHO2VcMTadGHb","st_dist_07":"HH3kyPQCOyYVuriILAqiufVb","st_dist_08":"s16tKajy5x6tvVvFpuTjSSqN","st_dist_09":"2TJ5xora8JCnKWD37Y4S5usq","st_dist_10":"PhpDi8R80CcWWOodf0k7yDYs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XjzEDTPT6Tl054JZ0OHSV2He4KC0n3pOIRxrHqrel032"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":448,"st_w_id":1,"st_quantity":96,"st_dist_01":"qJnczeCtTW8qG6mNw8rQ0TmN","st_dist_02":"DM7qwvnTFsxqZlEXGLIxguy2","st_dist_03":"kKNioZoMifErvwpKnqatWuhV","st_dist_04":"tXO7tZLl2AK4Iw3ZavnfYyCf","st_dist_05":"EEbfO5CHQc1G39fWfoV6y7ZP","st_dist_06":"ccjFXQQKKZlE26cinqb99fK5","st_dist_07":"ytD3xllCB8ommIcroDELIy2j","st_dist_08":"9jRvuwQPuYkoAi5pBkZLfnRf","st_dist_09":"TbEWW29ESwODylMCDf3tyfGi","st_dist_10":"0S1653rF2NrKOAa8fQ1Ds3ei","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2IhxambodwxxR5Xg6RuaTzofijlW9qj1qmEGqitc8ETzFhemj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":449,"st_w_id":1,"st_quantity":46,"st_dist_01":"ZqqtJL5CxTHOtOR2Kniawk99","st_dist_02":"mGcoJY4uoXDZ9CJM4eUdlv5G","st_dist_03":"uFFRSa2TJmkVEGYjq6tNSgid","st_dist_04":"OBjPy6MYVLe2kws9AjN3lPB3","st_dist_05":"3ONDROTJXXT7iI5X56KpstFY","st_dist_06":"Q79p62EYza8rzkgo2ClAZRgS","st_dist_07":"Ovo68p9d1adc9TfKSVPdlWC9","st_dist_08":"NHCAazdxLIFx8q5fcfBDaW5a","st_dist_09":"S6zdyeuDqY52pcGIXz6Pz6St","st_dist_10":"w6aRAk2reKaTjLXzJQjX1vBa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"49Dmsa5sj1gvonpA3cNzj2Kyhm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":450,"st_w_id":1,"st_quantity":77,"st_dist_01":"DSHKkDDpGBEQi44qYkdlePt3","st_dist_02":"3SLnpy4rPM3fXLktk0RPOmas","st_dist_03":"qpaIU25PiAJFfxkAvyJvbPjw","st_dist_04":"CtQeavjNZ6RoT7ZZVNqoEL5I","st_dist_05":"GyeG8aZlyvjzbU4mOe6gLiPM","st_dist_06":"Qa2OMwWzozsSInVWNDCFrMHU","st_dist_07":"7KWx6ge9mK1nLrowAB9dujO0","st_dist_08":"qKnv15vYksRzPYIj2wmLWWSo","st_dist_09":"E1LAxwl7JrVI6PeNiM3Vqa4r","st_dist_10":"4jyVFLuqYZ2t1BVX9W890eQS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ReKb6wMumlmfpoXFalAaADdNK8vwm1Q6b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":451,"st_w_id":1,"st_quantity":20,"st_dist_01":"GD8OwoHbM21NCC8qn4CU4bTP","st_dist_02":"5gJQ75RYKkQv24fC2wo2Qjp6","st_dist_03":"lZPfW1BlDISwXdRutw6EYpeC","st_dist_04":"zRMvpNYn7qTcJaKwOY8q4Weu","st_dist_05":"qcmuwpIwOtk1EZJyytu6tz5J","st_dist_06":"iyp5Q4y4Wti0NJrPCPUeXRMy","st_dist_07":"xqwNVckmYAOXtIVID5fYY7Rd","st_dist_08":"vkJ1EeSnP5O5Bhw3s6kKW7eX","st_dist_09":"gCv8ABixRxrPzq8tm6H1QODw","st_dist_10":"n5MPg4DiZj8NbOuce5lzd8Lw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ef3Bw9cQWAOrMl6QpMaaYBv6CJ7ynIJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":452,"st_w_id":1,"st_quantity":21,"st_dist_01":"f0XUwM2dUBtfKktaLEIobxw4","st_dist_02":"fgJp8HVZ3RSTUt2h5HN4Eu7B","st_dist_03":"v1d0k4BfLvYlZvqijSaWyeBE","st_dist_04":"xO7NTFiDtbRqdvqk6i1TS7oc","st_dist_05":"a3T3j7372tqfX70CLBJrJa4Z","st_dist_06":"L6WcFaQzEHAmrOeZSrgeUZcw","st_dist_07":"sce6iETvO3FLvozzCRWLifip","st_dist_08":"hopZWWQnJPoMtLv9YvnDg1xi","st_dist_09":"RpQz2loqY54jLQBfyNLW7zwg","st_dist_10":"j5GcdnkvW7bawXdagJe3T67o","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"i9QJWNMljFhQX8zBqXxkB2s9I3O"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":453,"st_w_id":1,"st_quantity":84,"st_dist_01":"Ql51HOhOdk8DEAnlEQqMfhOh","st_dist_02":"S0k9AhWaf1bDo1BEDrOqmtoS","st_dist_03":"y4xWmeKBOWCD2bXKorpszQj6","st_dist_04":"f9kBFLsdbSUaiaMKTP0nQENY","st_dist_05":"B2hOWnojCdBNvIe0wG2lV6t1","st_dist_06":"kPFUVMDL6U64MwVidrqF6qyv","st_dist_07":"x1LMy0nvYvyFKJMqa6sMFgni","st_dist_08":"R1jdnJteAyTP7GvmKrDqFtUI","st_dist_09":"JXAHp3yyYubMoIlvJBzKGL3b","st_dist_10":"a7AnQnAr86OTwV2vmKNFJSKD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3DEtJnWTPnQ1FDjNCRVz5hlOVarXZqupil0F5M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":454,"st_w_id":1,"st_quantity":84,"st_dist_01":"608CUVA89GdNfSeOE3x2hXH8","st_dist_02":"Ojpn1fTg9CkWjMZGWehd5McO","st_dist_03":"ViDc0WYAEdV3aCVDznHwx4Ny","st_dist_04":"JhDngfL4Inna9I6WhS3At0ar","st_dist_05":"URl7R6n485OwF5MHIyEaXCTV","st_dist_06":"EMGVFBMnmVm8ga2PEMaFbvbz","st_dist_07":"5uQsRMHqOJCSFSjFkXX23pbi","st_dist_08":"VtgMGYZ1pehMKWk4NzBplbRm","st_dist_09":"zlst2zOcPx2x3KkswlAnUc0f","st_dist_10":"ofx8Ut7GNirlk7bCeens7Qbc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6oXMuii2XpbbDRo9pJZOlZQkYT80tz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":455,"st_w_id":1,"st_quantity":28,"st_dist_01":"cxl5QndiwBkqHKForZqI8qlw","st_dist_02":"i7mLmyJ9UJ3IIH0LXCBPU5AA","st_dist_03":"QJBonE0zKWxkhxTYhi72K5K6","st_dist_04":"8JXeAQ6sz59IDgq3R0u4w8ph","st_dist_05":"DzdyMNuP53aBtaQyNUiz9EIc","st_dist_06":"yjKrRqThii7tA7R3xDpicOHW","st_dist_07":"v2B3059cj34YPHUvY83H7253","st_dist_08":"oDFd57nBq3qXH866o2iBq0bK","st_dist_09":"I00msddhbLL1vNIuY3szbzKs","st_dist_10":"IzSqXgQ4vbirstA63nMXmyRF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0DhhhJzw5yhlAnJAGLkV6DFObYs7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":456,"st_w_id":1,"st_quantity":94,"st_dist_01":"9WhKCDp3ihKsMCPkcwERcHZ1","st_dist_02":"y0Dqog3XSiXOIDbVEJMr5H43","st_dist_03":"ekxXPOFVdONKOMgIJG4yXfxo","st_dist_04":"EiWf9i2b1mmsORh676WwmauU","st_dist_05":"UTaBZdLbQX7qEeGc3Pdg5q4I","st_dist_06":"Qrd8kpD4DPYPTdo1cimjJxeV","st_dist_07":"0jSm8pxZvwjWees3qHg0r3W3","st_dist_08":"31yt6sclQIQbYEApOu83mz0M","st_dist_09":"jp9rCKzdYHPQb1BNGbsLxKOh","st_dist_10":"xga1Ss37RqEVmBelMkg6LgTW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VLh3ntAfLWRUuVgqh9lsRqrpBsxJIZ9rtNQ2TwOVjnr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":457,"st_w_id":1,"st_quantity":63,"st_dist_01":"luNeTUtistCqPpjGoDxcbNK7","st_dist_02":"y6hFwR7Qqmb1eazOVRdupg3Z","st_dist_03":"2BminLo70U4bt7kfoglmc6fC","st_dist_04":"DP2CA6SGcRQbt7T8q1WOXXUd","st_dist_05":"SlWE887I7pijCRrRgmJA5Q6j","st_dist_06":"OLGpBfy7PsZes2xJ3gOJ26cC","st_dist_07":"p2ITLplNxjllVwQ8y18BYEFX","st_dist_08":"1IuqmhksZEdiB3icabSpjQ8M","st_dist_09":"puiaw5iWrEXRKYF4cNk2ssoX","st_dist_10":"n38obhaIKp8O4InWkir1ZSze","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0RHAIW3ZIr98YdcG6lAhcp44GVPEa449iexKDH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":458,"st_w_id":1,"st_quantity":18,"st_dist_01":"G4E0lIRlfT36vnL4mEhqmXP7","st_dist_02":"eTTxzwjr4pArwqgiAZx4vVl0","st_dist_03":"e1n8CMerzD9dYQAleF0xuxv2","st_dist_04":"OWoc7Y5ZpTL1uG6hbgzMhQVF","st_dist_05":"mv8xzcAeb9xYouz30BdbVCz8","st_dist_06":"xhFjuIRwNxuJOhZPj4IFuXnm","st_dist_07":"2wB4vHGlIb3XhlCvku3QOkAa","st_dist_08":"GldNcaAvVLnHP6fDHdnuJYD4","st_dist_09":"yfJJmznurqr1fGBgf6P7PbO1","st_dist_10":"W0Jyqrjh4td60f37vhoqsEEZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9cEvp3XoriginalTnMPMVjmlPbN6e82"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":459,"st_w_id":1,"st_quantity":16,"st_dist_01":"iWJx3kElLbyl2aMAYQnObNL2","st_dist_02":"GmS00msjv3qFU9tvGBsQLzrp","st_dist_03":"1sGAdBLI2TugBWd4VpCSBedM","st_dist_04":"HkiBrUjHBMnXCkMGQX4v2kJx","st_dist_05":"SrzhS9s1NY5eBqiCFzNX2su2","st_dist_06":"iJWRZce16z1XutptSgUyUmLE","st_dist_07":"GG5Ud5UCr1c0GrkRFjisl6O7","st_dist_08":"h1746UhVKjRrly5tQuzWRVNz","st_dist_09":"Odlw4w2tSg61qEwwrurkMJsD","st_dist_10":"HmWg25F0LIAtfsiMI2UUQ71E","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"itwQwzPv7Dc4jSXk89t57Co5b2Mel"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":460,"st_w_id":1,"st_quantity":93,"st_dist_01":"7Pi93b6IRfjUJ9sipEMeg4qV","st_dist_02":"2UlZhq7rsNtvtYbOcNbEbLGX","st_dist_03":"D6FnxvD8EapYn3kkPugEVxhk","st_dist_04":"82oyJaqNDKQYVW2tsTKZsgwX","st_dist_05":"XNN1sufa1FVxn9EIwQmtZUdo","st_dist_06":"xX455Rl7Hrx59AmIKXymm2BK","st_dist_07":"NjVbCDYnb28fyvLKjgMDFwx2","st_dist_08":"joo9B6JmJesqyPpIycYisY6F","st_dist_09":"WWzSZFPOBcZ326B1w8DuEBh6","st_dist_10":"nVaeiJ28qE9kf6K8thY5Ukzy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OGJiErDkcJnO5UuhzmOOO8L0SspXb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":461,"st_w_id":1,"st_quantity":74,"st_dist_01":"nAC56Glty5RC3MQXMmcrr7DY","st_dist_02":"wRIViemnIsE70SosH8D14nai","st_dist_03":"7FOu5HbkygeeMXDkFx4hOxb8","st_dist_04":"c1bFjU82IebuPCnbHElGRHZj","st_dist_05":"TDZPyNf5ZOd8K3sDT6UKWvBQ","st_dist_06":"oR1Ysz2uV2PnOUpHiujyE5Xf","st_dist_07":"cSXGXBMmNN8pwaK042bRbgfR","st_dist_08":"h19slQ4CaorO0CHRb0zI9p8w","st_dist_09":"u3s9QRRgFJF3Psa9Aa5EKl4E","st_dist_10":"sNLGmegDCqdqu5UBabsDfeUT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1qhCpevCzEulJxZbWaHMU2Eya1dZCoFYtgrr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":462,"st_w_id":1,"st_quantity":99,"st_dist_01":"RfVc8pbiNYjetMnpfarNkPCL","st_dist_02":"39E5WhdYoGihP4KOhNk34DDQ","st_dist_03":"KmxBbLaIXjLBNqs9FX7u8w1f","st_dist_04":"dk7Rz8sgvospesx64WZAqhlU","st_dist_05":"pc9qSJehN5TOZ0W5Kftry890","st_dist_06":"0p1wh115egibdrhiZT9IZpvi","st_dist_07":"K6dkgZ1OKsmN6SmOhnNa5DzX","st_dist_08":"c8DfoZ7WAFaT5uOWn3goqMMy","st_dist_09":"8UQlqPZ8tqkQRdDEZu2lVLBH","st_dist_10":"thDqZ4PNHYPhEdVTJloCvsHE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"STFHVRg3oVufYnBOC77Tq8yofFdhNvRuB1EAWWH2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":463,"st_w_id":1,"st_quantity":72,"st_dist_01":"pFqEB4KbM7IJ65C7vtB5OkAA","st_dist_02":"dyfPHjyDWlVQEAHX4GbjP9Vg","st_dist_03":"817kNZp54p3IQfShO04OY5zg","st_dist_04":"89WWH3PmL0RCIStUd8kBX8Sr","st_dist_05":"TcOyzOKx9M2QiyXIztm1hPoK","st_dist_06":"BT8XrfoQgkDxzbAArGaonRoR","st_dist_07":"Y9IpSo2j76dpKekMeps7YW3I","st_dist_08":"SaN5iQ3uSpJJQOrdz4E861yE","st_dist_09":"B0HXkaC0pCoyNDTgo3fW3hdQ","st_dist_10":"hnWD5tjzqDjxvbEDLuPRFnzq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KrR80F2cSYSleu19p3Fm3y4J90lpaFh7Fz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":464,"st_w_id":1,"st_quantity":46,"st_dist_01":"7BkRQy5tGhgFLGqTTSmYldWE","st_dist_02":"5HP4fA7pTwJHUarJjXoykDyH","st_dist_03":"mc8GdYk1UhV1SB2bdo5UCc6r","st_dist_04":"M9ufy1TpL2ghdTUsjCjtmmfA","st_dist_05":"JxiUrHgnc3KlnmutWfQK5qGl","st_dist_06":"hKZDpvEUdDRylGWy5FC0Wsv3","st_dist_07":"XWqg3yUcqXq0wrsGo32CKKIh","st_dist_08":"LjnfvR2QRBPPnRp0CJDIrkch","st_dist_09":"PVqY77HU12suEaqFI63Tnqi3","st_dist_10":"NT2VbpexebU3TibuL26E9rxD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cLkgNOyj676tBYNWAIhlVzgjjqWQ0cecYprLfi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":465,"st_w_id":1,"st_quantity":46,"st_dist_01":"tLIq591t2GvaYVHjgIrA8Z34","st_dist_02":"qL7krMgFI4CuO2DXGnvcTAXD","st_dist_03":"BAuMz3cSLW2C3TB0JrrhRjT9","st_dist_04":"tpURNsxpqqGujdVK2jHKI6Am","st_dist_05":"fUEnZcnlI6ThCDtDVh99nIF6","st_dist_06":"I87E5EA6J0A1VIcZWktQrKgA","st_dist_07":"cqQMwOHRfpr5PXze0X7UFDBS","st_dist_08":"c4AHWBLWKtLiU5CMaSaRJWJ9","st_dist_09":"XuqaqQDrZVSzMQ72YqV1a3a3","st_dist_10":"lWIU3xXpK0wt2CsVzsEmgb6s","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UlTVqxJmW2LsmYa7y5nHgGR9l3PUVZDO7klPca"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":466,"st_w_id":1,"st_quantity":99,"st_dist_01":"qwFBYi3wh6sMT7BOqgDxgDbw","st_dist_02":"oR6t04jPZGtmktlj0D35DTNp","st_dist_03":"fxVMj33WwWLpssr8Q5lqweFa","st_dist_04":"Xpf4ApZKUVlAUWXDUG1jqpgc","st_dist_05":"oPjRrUIK3zeMXmyMmmhFXhHt","st_dist_06":"4qOUqPJTSxy5zRoyRZAazXOd","st_dist_07":"lUIJD74uYVeW97J0Q1hRGBj4","st_dist_08":"UD1EItGGZiiojY9Lg1lgKASm","st_dist_09":"kNK1O8FwZxF6H8uS0yoSMu9e","st_dist_10":"zb3m03hzItHhcDK5TEeyYlOC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"j0EeJI29I6GpXNYbpLIwnSRSU7FTYCuWvXUN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":467,"st_w_id":1,"st_quantity":56,"st_dist_01":"8eAw1p0tvzKIVU1ImCWDWEGV","st_dist_02":"y2sHCcwmMqzSXkrZrmaiZsHJ","st_dist_03":"8W5tS8UHhefo3xsgJFa9SsrZ","st_dist_04":"L5rnlkKetDz48uifCJiUjIOg","st_dist_05":"L6HvzEiqX46T3TUJfdPSve6B","st_dist_06":"WEx8J1DVXrexzc2rl9SntE0E","st_dist_07":"iIQ18tNMi97Na0BZNs5sA2xd","st_dist_08":"fNBi3gdZKzl7Eq0MFiJF32du","st_dist_09":"aAULwqpTkduwkmfc3TL5IY8R","st_dist_10":"JWQc47A0nijUyCBsvXlngflg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WZJ7BnExpHD8hQN5YqqTWlFG4QqmHw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":468,"st_w_id":1,"st_quantity":56,"st_dist_01":"VHs9LFCPbxNe91SUGK62U1Mj","st_dist_02":"hlLfELD2N853HBMVI8cCiIPc","st_dist_03":"DOwtMYweKhi8Ycc0k2N7hoPs","st_dist_04":"rA0EKg3nFzURAA98jOGUtOBT","st_dist_05":"LE1ETk1SCMm8XGEF27Q3icI3","st_dist_06":"ZKkZSjS0olptBw1FDmkjuhdF","st_dist_07":"YNo0OOdM2GnbGJW2GnOdd86H","st_dist_08":"DodsqU2dbWdO9TM8b3PP3zfR","st_dist_09":"ooMzT8QNO8rpEfja2XSXsDo0","st_dist_10":"vZNpDanxPlGXyMJwiMPUpjQW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JrqQHlmsPHAzi2IlDIrGw71SCYYPkJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":469,"st_w_id":1,"st_quantity":26,"st_dist_01":"bFoLHM2KAG2A4eirzNtVVRQs","st_dist_02":"k2Sgw6dTal3heV0agx5orXY3","st_dist_03":"6kSwQRa9tTrXXTbkzgZnjo1E","st_dist_04":"PlIERCqd8l4mZmESUWBbMPso","st_dist_05":"umx9UHrtHO73jdwrfHhDozrB","st_dist_06":"lRitYcuTgLO8u16TrFHmPXnl","st_dist_07":"GOcipHE3owHQwX9zGJZTQtsB","st_dist_08":"lFSAaks6aiqCbGaY136XAnMK","st_dist_09":"iIoG7vZZbvHnsDGk7gJLC8Lt","st_dist_10":"r2fGAmZw58MIvM6yzhyuA3zy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"T7GfHamXEHXvxUoWL1raLZ4Tt9RukbOQcN68Dou94c"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":470,"st_w_id":1,"st_quantity":28,"st_dist_01":"sljo42Rhvw3PRENH1GFt3jTi","st_dist_02":"bcHQ2fQm9DlajJBXDds91gbn","st_dist_03":"UarazGt5XIOfwTHFFIbVBLTh","st_dist_04":"EGwNRPdeOn6ECsyZIzvNW6Wr","st_dist_05":"QGpVcBvle6mqwkpqdanlimNp","st_dist_06":"olzkaUXQB8nqOsWwCAAVyWAB","st_dist_07":"6D6uDC8LaKe62nNIUPOeycjt","st_dist_08":"ejWvZzoPiyNUXH1Sgtbn6GRs","st_dist_09":"fYpIkvhy2aTw12tPl7GtshUX","st_dist_10":"thKgXudQ5G4vRL3mXKYBnoBJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"n118yLWx0UoBwawJnRD1ASlmAlWHdt6EbV8gZfbTh87xy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":471,"st_w_id":1,"st_quantity":66,"st_dist_01":"m9DkpahFYc8Es6ByFr4y67PV","st_dist_02":"jw9B63Gwy2mkUYoV9NSWbDeD","st_dist_03":"OVlHp9E2CP4o1Nl55jzOPbjO","st_dist_04":"8n9NBDS15sH732UTnRh4Dj13","st_dist_05":"MWMESRRct42JxomPvRKbyAxZ","st_dist_06":"lWu3Rk1AXRzMnoApwyORklUY","st_dist_07":"0h8MUtTVpIC1EzRvobEPvnFL","st_dist_08":"4gZd44eaaXco82fdWuaa7y6J","st_dist_09":"Vbf02dFWZAZAPjDfJNZlgmA6","st_dist_10":"ULBx38YlHqaalUOFgi3LuunO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3Wsk4RUC4YnVZ3hr567Rml4NxsLDDRuzmLJewEVGr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":472,"st_w_id":1,"st_quantity":34,"st_dist_01":"IzE9Jxlhe0uAdl2EMA0ruhZE","st_dist_02":"KwLcZ49JMCJSXbVHozkIDD1H","st_dist_03":"OvpLz4kgN34M8gC22qHJMyN1","st_dist_04":"52HvAgtNGnFS87gbtKSe2FIV","st_dist_05":"ZKv2AdbBWldu94pe2XN7dPSa","st_dist_06":"DSxA1ZEFCvLXU1Aoad5722nc","st_dist_07":"cVVdSvmsiG84P8PLyQO1ufRA","st_dist_08":"HNv7xHxwuYCd66DailuhAOFI","st_dist_09":"LHw16dYlTrRjoHnNBo7rSv6W","st_dist_10":"9bvmkN8OMUSZxZ89UIisl1m2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"19MhaFaBnLXyzvZKIS19D9hJojvR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":473,"st_w_id":1,"st_quantity":34,"st_dist_01":"NrkM6dOjzUZK9MCLI38CMfBM","st_dist_02":"aP7jqhzrgVSUGrkmegL0IrVs","st_dist_03":"tLikLFYiLpD3trDNSWOLffqk","st_dist_04":"ugwBxOe1APXR2vxaA2bVk0hD","st_dist_05":"4CGMORzQt3YVaZud5WYHr5Kk","st_dist_06":"8v64KfPS9DV29rgY7oFgvBXH","st_dist_07":"oPzCj649BV9XgSPVuXKz552I","st_dist_08":"sPViDG6fZBs3jgifJccYt0RZ","st_dist_09":"UlepbXRIafr30etCzp3ohAux","st_dist_10":"Y2wSlrSQ14iuhjhODMqvgbZX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TwnQCnkiZWxHbR2aHlKoEjqtig7qjEaORCxn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":474,"st_w_id":1,"st_quantity":84,"st_dist_01":"oMddxBDobBdIlshMQfzFacBN","st_dist_02":"WqhBrXfsAzElBgSHBTsOyKVD","st_dist_03":"utujaFhauLNVJkFpkyuL7LoI","st_dist_04":"3WdE5kQEcvvqhyj2gYeJhNOR","st_dist_05":"5XBgSucLXlLH6shNLKNsKQQ2","st_dist_06":"T6h0F5nU6y2KPGgKRHKEjtFo","st_dist_07":"NpDxf20jDqt0YvuMWbRGucNx","st_dist_08":"vIGq3hYdmDwhdxblqzlkylIg","st_dist_09":"RQJjLLlsRfs4JAOxVwhDIsSu","st_dist_10":"twV28ixb8ZOCBWGSbvdIQPgU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xKUsLasgZ1lgk03Jb9aC3aMODgg4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":475,"st_w_id":1,"st_quantity":36,"st_dist_01":"OvRptVe3cEGxjKeTKfFCmbNP","st_dist_02":"DqzkOi5tZGGeAwrPqyT6Jjab","st_dist_03":"xH3fHj3ifFNJI0mWRz8lOopY","st_dist_04":"sbWlFOZ3QIhT3Xl16CRF6xwq","st_dist_05":"CqBJVcqYupOegvsai7rw2K6r","st_dist_06":"95qjBT5HiBDwXnzqKoWwzW6Z","st_dist_07":"qIfa9QJKRSB4DoDGniDcwKXe","st_dist_08":"mEe3dDOKMV37W7AIPjAiHARN","st_dist_09":"abtJRz6aKU5mpsv797WV9nPy","st_dist_10":"Rdzv49Jo3h6kO4WWANfJn6sM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2hVaEdXF3w4s3whDDdnQPtMVZ3YQuGTuvj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":476,"st_w_id":1,"st_quantity":70,"st_dist_01":"NXgXS4K24GA0ks2XplLJwipP","st_dist_02":"Qjr0nH55wQAEiiLwPfS4I02E","st_dist_03":"bJrU6qdgZXSif8jJ6XkTGtWt","st_dist_04":"CDIwJmbq4YB0MP6KZBVo844p","st_dist_05":"G1n9ne8kFNpSkQ783MTGAwFx","st_dist_06":"RKED2Xo3AG88coQFKM3bP4lk","st_dist_07":"5WiaeynwsRFCJ21hUOnlslch","st_dist_08":"Ywv6BeOzT4YwDmCYJq2hGZwF","st_dist_09":"qGHOhrK30U1SUSE9GTTjNp48","st_dist_10":"7jhC8MYn9a4BBhTOl9TB2GkW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lzeypYIK3TGAaM6BTOUsycCmhg6Hc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":477,"st_w_id":1,"st_quantity":100,"st_dist_01":"XaILlvVP9Io3LWcYOtN3BTEB","st_dist_02":"kCmn4KNlSgWFqgHejuFUyQyl","st_dist_03":"vxuhRMqDPUSfGxoitpr0naA6","st_dist_04":"u4ahXILKBWxdwNTKNunYkbAD","st_dist_05":"YikmSReRPAXVAbTSaxyuJ1I0","st_dist_06":"h6l5LsFt2pBXT37zuQqXILoG","st_dist_07":"gYsxrtSFw6K4ESd6lD6XtAmB","st_dist_08":"mQmE2Qrj4Ek1f76LRKIu07U3","st_dist_09":"20EUDIWcHi9SHi08xwgP2CeV","st_dist_10":"jl3Zz9Q5IyNr2T56b9cYesEp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JzfNNjoAR87RZROh9xebRDbqwcB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":478,"st_w_id":1,"st_quantity":52,"st_dist_01":"AspboViVVqC92L3FDay0c9fQ","st_dist_02":"QlLKX0YjIQzGujjXqhWIhcRe","st_dist_03":"4ySSuPgnJzjOHZVpjHFVOIO8","st_dist_04":"uV6BFFunZBlXcbhrtV8fn5ga","st_dist_05":"Q1oyxK9gfnrd3q84RqpMyQam","st_dist_06":"04bulGv61TcF5Hj0kAqugOBo","st_dist_07":"4DTowsBEaoJFxwTNqUdGSXFK","st_dist_08":"hlRHBnR9NIR3i6XhGHG561W8","st_dist_09":"7MlKDI0TnTpD9x0udyq1wdMz","st_dist_10":"8mI8yhyknU7iUD263nRlbdoy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JijDMx74xmwgja8SF0l7EiXZ7NJqk3zAi4LkvHh6Y19XYsrl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":479,"st_w_id":1,"st_quantity":71,"st_dist_01":"9btFAy5zLV34q6zNG52s9SpQ","st_dist_02":"3alxZ59TMVFTa5R4b3owcw6w","st_dist_03":"cUk6jUtmqOuWEJ7YdDOyLogW","st_dist_04":"rG6m9OHWMYP5HVivXfBqniEs","st_dist_05":"5eJQO1yWuYnOHyCy7wgjd3r3","st_dist_06":"iYdtAMLjAgK2UbYrpblPjL1B","st_dist_07":"QvWf6rBvaZ330wAzjqH7M6Cz","st_dist_08":"bIXWgVZp7DX5ZTfkEIwQtaKG","st_dist_09":"ofyv546ByxIOTNLnUbS1sy0g","st_dist_10":"ZrS7yjqGJwXFWpKa6nuZU06W","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TUQpB57xMWGRi34StPsEHM4yj8u"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":480,"st_w_id":1,"st_quantity":23,"st_dist_01":"LAUVn1KNv1NLmDU1m4pom0AO","st_dist_02":"OtJ1whAVnGdbRuX84ASQ6Qur","st_dist_03":"JL4hlep61KrEDCHE6ahGYrA1","st_dist_04":"QiDJkBrFjSCW5qGPvdfmgtK6","st_dist_05":"xdFu0fg9cEZTCpk64U08zcfY","st_dist_06":"KnQ17SczAjztHLuGs6EVQBb7","st_dist_07":"2oE6OkE79kz0Ocvz1cS1oq8y","st_dist_08":"7VRVmZVq2qsLPBw0ksPsZ6WP","st_dist_09":"6RS5cJW8GRhJd5cwLH9Vz3ew","st_dist_10":"oTPTIogigY5fsbd6DPeV0eZU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0JdXcvHI5QqrMJTfyBGSzkSJ0uuv0P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":481,"st_w_id":1,"st_quantity":70,"st_dist_01":"D0bMPm2y2rsYAmdvajL3YctG","st_dist_02":"6gQA5Ai8hReo03BefmtZuScD","st_dist_03":"zDFPwJNNlWovlQ6wrQVernKf","st_dist_04":"C16rLrOAuvozKlVc79yIskKX","st_dist_05":"HbG5GLAKIXDbcoHeOyFU7TuM","st_dist_06":"N9T64LrMV1kV0YPjvWF8OIWm","st_dist_07":"pSKKzI4b5ykgvKIpHpI3ivYQ","st_dist_08":"JtfTezbQnbSSDgriOvPRBapP","st_dist_09":"1vR3qZt0XIzkNiI12AtOs3ld","st_dist_10":"7H0fUYiMGYjtcpN8muBSg5iS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B6qOR9791lat2lSSCyGo3MLvRE3LtPB2W3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":482,"st_w_id":1,"st_quantity":97,"st_dist_01":"QnKBtwMGMN7GN5wYkfPTkpK1","st_dist_02":"eIXp5KdmKbNDr6TejqqMPE8N","st_dist_03":"XO8QxqLWIjuBOM9F4FoaLLur","st_dist_04":"9Ta2UwxILjgaFoIbIN18kDwc","st_dist_05":"DayaRqJqcJKOia4s9KykU60m","st_dist_06":"FtipbSY5vP7xqofNGwPVK4Ib","st_dist_07":"Sgaw8YXXcqiD7EV85TE5x4o0","st_dist_08":"ings6lCkz7z4Qu4DpeVbVKUg","st_dist_09":"huFxNaji7xMgLuuXt4dMIOYd","st_dist_10":"zQfDvfeb7wHzoPYFugFHQH5Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vnONIvm7TO3t38d0bW6zZ9xHl6jvr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":483,"st_w_id":1,"st_quantity":37,"st_dist_01":"wrQ749qrJnVlWf64hqEcoIGp","st_dist_02":"aV82XOyieO4onGRv1rFvBJ1L","st_dist_03":"rOY3BAGl88zXlsuhG91PhPBA","st_dist_04":"45uqfARh9YyUr3RovSVMEG0S","st_dist_05":"OugsAwhn1gjRxBGnLMHwicIQ","st_dist_06":"ih2Z19oHujSFV2hz1p4OftSM","st_dist_07":"ikSkwGlq4x0XEGPOLnOvZzTT","st_dist_08":"qBrN3u9Xkbqr3HEr8KFthfBc","st_dist_09":"GRmRn9J00LNnf4ig5x5z9RUz","st_dist_10":"psDSDVlFLQEMHPHH2MPJdRxB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cEBD0miHXPGLD8VcLPAZekU7zG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":484,"st_w_id":1,"st_quantity":84,"st_dist_01":"cxwGCwnDiyzicISivhX5dmkF","st_dist_02":"8Nu3VFW8ZdPxuq12iv2hMQCU","st_dist_03":"vx5WHWw5zEGQpEXxzBNi8F44","st_dist_04":"gBOX3mY75gXfavIQVhQrERln","st_dist_05":"qNLhgxDrDDU5v4SnpKu2WZW9","st_dist_06":"OLcsObp5at08E3jYXHN4JRFY","st_dist_07":"q9HJsDkzhEudP1Vxezau7Bhd","st_dist_08":"ETgcXMCouQQmPxsC6yfYkdcx","st_dist_09":"imLDKDRD4ZKCfzJhCNcAJf9Z","st_dist_10":"uHKE1679Tv1QAQ8Uhohau3M8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iiWXNKYlGWQsChXJB1xZFPl0zAA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":485,"st_w_id":1,"st_quantity":40,"st_dist_01":"xmNEoXFHguPSAaE6nNrD4oz2","st_dist_02":"AAXz2BTCM4WMIU6dffAypSqc","st_dist_03":"mxUPPPkd0O3kbq41RLwAXnwT","st_dist_04":"B8L20ENc6U6tzxgJwZT3epDe","st_dist_05":"yDWLK5hSw6UuAsWrGhQQ9RUQ","st_dist_06":"2Y6XOGmbEXnFrcno2iBUwCY2","st_dist_07":"aZVD41M3Sp2t67VkIqHHTlgc","st_dist_08":"sNiB8xsv8vRdJuQdDFPhuXEq","st_dist_09":"JebhlNhEUKCbF2zcmDKDgAyT","st_dist_10":"L1G8UNR0pmrscYBC4QUoNvHq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SxxD2KhoD24UGZSOMYlxsVYv3mv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":486,"st_w_id":1,"st_quantity":75,"st_dist_01":"b2f2u9ASEgh9LkhEwxnbt7I8","st_dist_02":"W1HSun76JeHJkzgrRFKKGe52","st_dist_03":"8jI6FyzA3iYvTl32R9XrwHWk","st_dist_04":"VgGH4dqzQOoBFHrPjOwEDKfH","st_dist_05":"LpNU4EFpbSkuamztbdNhZnl2","st_dist_06":"utiHueRXvdGfbhy18on9NNrK","st_dist_07":"FzElblvla3PLC4RPIQwloqGx","st_dist_08":"FZeSnIVdtLkKYXs93brys7lg","st_dist_09":"1f3VvwswQ9b3tUZoy9Md5WV6","st_dist_10":"RsbZE2AdLjULJCPEFwWBek7Q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ldG3PTtm79yADQDvZcOPo7cgYfuiqj3dl3re"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":487,"st_w_id":1,"st_quantity":51,"st_dist_01":"4ucwJoAkYJbfQSd5LBvRnCEu","st_dist_02":"pkAFXbnza50tCJtL13xYKkRn","st_dist_03":"h3NwAGOG3dv4RgsFfyEoIovo","st_dist_04":"DSde9XDoXjgYJgzkJ9YQu49y","st_dist_05":"nepG1DkSBV9EbCHLvVi3TRpK","st_dist_06":"eFsbKYHdomkeODguWVoQOYNN","st_dist_07":"pYlEw8oMMgomMxzukNpKVwA3","st_dist_08":"ilD3vAlS5iQLdyWPkkg381KZ","st_dist_09":"mwGHM6QobwkE75ezstRQlhZJ","st_dist_10":"kvyGchPP9DQlPoLVcf4EtXwW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IFIhbVYrhHa4KifutaGduBdy0sQSsWYzS3Y6Ka"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":488,"st_w_id":1,"st_quantity":100,"st_dist_01":"fIxMDxFxmCDzjeasC5wYdNPu","st_dist_02":"kGH6d3vm1mW16NNAS8HM6HRU","st_dist_03":"VeeEox3fPWlKNCNNLDRbjot8","st_dist_04":"YPNJ5hXeWyuMzZh7flNqQcwk","st_dist_05":"sZX3sg78JCuV9bTgBJHtqJys","st_dist_06":"9YPx46VLyoICtvxh1Q9slKHd","st_dist_07":"QGqkZug7yIQDVPoA1Hs1nPmg","st_dist_08":"j0K5umvh4IqBxiSGA5LjktIZ","st_dist_09":"DxkcFB1nlp2Rh6FNMmVRMCRu","st_dist_10":"qCjLwQ55rWZwUfuy12zwp0eR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XQctjbxImSe5zUPmivHtHHkRK989Z2gCpEChe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":489,"st_w_id":1,"st_quantity":19,"st_dist_01":"lDd5XFBiez9voY6MWfQXu2Lq","st_dist_02":"sVqxaNZcZnAqlwytgGMghNZa","st_dist_03":"Nz0beHo1uKVThTTdZu88pKdW","st_dist_04":"uOouKyDqSp0hHA6XLaFy7tBW","st_dist_05":"59vXWUm3WBgalaSrL0x2ffOe","st_dist_06":"PPICnqzlCIwBNb6y6DLce2ry","st_dist_07":"sckCdhvajqDHdWRIgIZHlUdU","st_dist_08":"Q7tD0lfNwjofJBaIMESQ4dgb","st_dist_09":"VtL2MCussOf7OSGu0JtZsjeV","st_dist_10":"p1dTT2SsR15RxbkTMZVIe96Z","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WUzAxJZXvJ8SyWGPlgrTQsU1WIFmr2tyLlgdH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":490,"st_w_id":1,"st_quantity":62,"st_dist_01":"LB3Gh2JVyMp2mV3JONfC5sjK","st_dist_02":"a8mLEuSGkPUv9pSSLQ4pEqm7","st_dist_03":"Dz2FfdXizfwh7bdcNnphpwkQ","st_dist_04":"utRdQX4vWvjkrTMHvymmdrRn","st_dist_05":"l9ATtkZYEbge3OboMtfbgg82","st_dist_06":"qExKOjTAVJtnwfKN3kcHVK6a","st_dist_07":"SRbQFkxfovzzgvKKz8MdydiF","st_dist_08":"dGm3pt4GmnCwJV7XuY6aeZxT","st_dist_09":"G67Dk5ml4vOWtZpmqKXYchHo","st_dist_10":"E8Gi7nSLteRONfiojqotfw3J","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ak2PRhDYdLkFa0zZGgNWpY8ZIi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":491,"st_w_id":1,"st_quantity":47,"st_dist_01":"o1NhwHkeJLBYfiUu53mZ1CRl","st_dist_02":"hisa2QOLJdradrvMoMILKJaM","st_dist_03":"YrbsiC3EulvTbYDi4gz6AoYF","st_dist_04":"2OTO9tHLvd6T5FUKGWOEegAZ","st_dist_05":"MOibY7UaWyapijT6TXKLD9bT","st_dist_06":"Fl6vbm54Uuk7nYyYcPGi4S9S","st_dist_07":"QWGzXhFrTxa2iZyXCtJxJ8Nh","st_dist_08":"UTBrzXAeFugFvMrxNc7hPy1x","st_dist_09":"EDzwOtL5AmXbXB5yCHrdTs9i","st_dist_10":"HVWfpbKdYzYAVnXMIkWvkQ8C","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cpruGCN6Px1nEh4doriginalST24tTz9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":492,"st_w_id":1,"st_quantity":59,"st_dist_01":"gYe9GBZEb5NxqCK0JX1DDmg1","st_dist_02":"kCQs7Vu1ScuFrkwmWozy25hu","st_dist_03":"V4sRZjCbWCbikd7qLTVr9Z6P","st_dist_04":"SQfj5tbvLBhu92IHaSpjRLy1","st_dist_05":"52mX9LK9rTZlciig4WH5yi6Z","st_dist_06":"xOyLL0dFX41YtlLqfvCWFYdC","st_dist_07":"bAL1bziWxKONq79qms1ExkuR","st_dist_08":"mRCeux6WaIw2NOnD6VG4egab","st_dist_09":"rhb5swdbRyTcFMYAG56jAGuG","st_dist_10":"ymrXQmFypikYlSEe1w5oC6LE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TaCkA7vJMworiginalZmhOzc42clSLWbZ80cc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":493,"st_w_id":1,"st_quantity":35,"st_dist_01":"jfQW6mPiOBurvEhdrXAEVkpH","st_dist_02":"MBPYl3KPN2JeCWqlqAfLQZt3","st_dist_03":"kwaKdZ46mgqtJSkmEdu6jgYL","st_dist_04":"rFDBE934kLiRmI0dPDJBxnKT","st_dist_05":"Exz1oLpfX3qJrJbDUsHsZtYg","st_dist_06":"3KSSh0rbqkTcinjTxUOoBrGP","st_dist_07":"fWjMJ9Js4isFxVj9e0016Y44","st_dist_08":"vCNhJvRol2CGxW1lsElU8gAh","st_dist_09":"30rs5fJ6uqrFQDCp2aqxG9Jc","st_dist_10":"WqC6KoYA4PQqtpnI6K44ZmDV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cxWHrDUJd4cuZf9mIEsP59gGQmlBjjZ2gJ7rcB7VGb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":494,"st_w_id":1,"st_quantity":59,"st_dist_01":"yC9LZsaNIOmIJLGfuQCNt0fs","st_dist_02":"8NLO1WvhFRkgb7cbyt1KXPrK","st_dist_03":"kyEoT3C73ZKopXOuBWbX3pPo","st_dist_04":"6be8yes6EGW3FR8OwwGSlfZf","st_dist_05":"9sGr2QWPSiuXhaeyu9n9xWjE","st_dist_06":"4iPbkQsu3KvQkaBFAeHg65PM","st_dist_07":"JiZAzNyZywj1yBWLKLsMV8x2","st_dist_08":"7bNpMqDALdHvkVHbAWssyU2w","st_dist_09":"g0y9uax6TLgS9Ibngq1NSgqa","st_dist_10":"F7RC9KsI4JRJNFPF1Qk4y9xZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"N9Gjrh2SamIN0nm9Q8MEmp90NtAZEJeZtIIH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":495,"st_w_id":1,"st_quantity":95,"st_dist_01":"aEBdZD0PNhCptWM8LXHiZ1u4","st_dist_02":"RPaSrRUk3J0sQIHP14LBCAhV","st_dist_03":"Nx3gtWlew13Pfe5p0GsR4LZ6","st_dist_04":"it5R99jag4Y7AKXFBwtddMrp","st_dist_05":"4S9QuzBaARZNPkJ8ubIN53fQ","st_dist_06":"zUIQGRgOi3ZXg9Ie6e4YFFSb","st_dist_07":"liqRUTmENmYe2fBLxVlBS6ZJ","st_dist_08":"UFbIOFIQCDSYwIdIdzDpZ6iM","st_dist_09":"CqQ1j2S6frN30T60pmwAhXG3","st_dist_10":"NNISiZSCiNlTMtVpbG3i2XN1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vkhUDxImkyEUuecOS8uYKVjCWru4oYFJt72rWtfe7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":496,"st_w_id":1,"st_quantity":92,"st_dist_01":"HlVakZYSoytoLDmdGf3SVpxy","st_dist_02":"yxQY5wqG7ijFRravoxcQaFSd","st_dist_03":"8kQPEVWQYu18slMSyIpijPkd","st_dist_04":"oOLYKz4P4PbBolcRYO6m0oCs","st_dist_05":"L3fzG1A97Q5djbkmKgFBajdd","st_dist_06":"ISSzTVfwj1j0nemvpcSAQpcD","st_dist_07":"o60XBzMSMLzuYTsVIfnK24if","st_dist_08":"5mzQdVEWVQ9Y4GOE3IwBvnvK","st_dist_09":"EoztwP0wgippvNR1fDA1Q4gq","st_dist_10":"EhaaaWpcJFvFhBJ1rmFetKXG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ILvwLmeV9MW8YzANPaQPp0jtqNqhQ5shB7pUFitCoP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":497,"st_w_id":1,"st_quantity":31,"st_dist_01":"JuYnbdzj7hF1X4rAZjsSdEg9","st_dist_02":"L3GI9GeLTjubrx1BBVNDyiI3","st_dist_03":"UkkmDZpgYVku4LcyLA34CZXb","st_dist_04":"tk8PE6oXOf2LGPzq4LkcRXOP","st_dist_05":"hiZl1dz1eK8zbQ7uRnRhwU0B","st_dist_06":"98TJwQkjiuqPheYHjMnWtjAs","st_dist_07":"1rLiK9d2PkabrIygnHdX9uz6","st_dist_08":"YpuY0gm4HwvbeTHVhziXnSww","st_dist_09":"k7FXtz6LIpGANaoj5QUaW12B","st_dist_10":"GHccxyv4ehK16Ru9QFg1nTzf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3gvj0pBaGbKfCsWjOrttIdYsHJg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":498,"st_w_id":1,"st_quantity":21,"st_dist_01":"pJkjlpknRZ3kjbaXHro1ZfPV","st_dist_02":"Q0mxeGtS4ZavIWb5aO4tQwxk","st_dist_03":"2VImAzzo6kkS4iairOrr1Zqf","st_dist_04":"iwDUjkLLxjyT55ki36HA41J5","st_dist_05":"u3VsLnU3CGjsABNScnPKIyXQ","st_dist_06":"C08HhOHpyKvOOxAUwhFRtdRc","st_dist_07":"mUv9nFvK7DABMX3BQ4mrTJFl","st_dist_08":"0ut5XcV9p9mlSilZhgGW09an","st_dist_09":"HYJvaCWSi2LIHP6l5oUVvQ8P","st_dist_10":"JKbY0HwkqPt7pe9LXbV3NhjJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nm9oN3DwgiiXoMhXoUaFFRLoriginaluFqOZs8SRWeHoiwV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":499,"st_w_id":1,"st_quantity":91,"st_dist_01":"izMjXPu4meFDLkFeizBj9NBs","st_dist_02":"1IbSNSrlr4hsLkwxFHb8mPbe","st_dist_03":"Vwoohq1ld78RJDLZ6sV53Jtr","st_dist_04":"OvCrcEpi0rECv97zXOYv0eWY","st_dist_05":"PTDKn2RPnRDYi2mZ9udJgt0K","st_dist_06":"RPqiTK2oHd6HVSlUEqqH5qNA","st_dist_07":"PwhSAGPCNznTrjJ9HgmPiyef","st_dist_08":"0J969ctingyaSvz1tBbJsLVG","st_dist_09":"nGbFbV7E4yrYDvLGZr0Hz2y7","st_dist_10":"MaqXflbqxH3bTqnYvLenuZuf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R3q3BKWTnjzSAP4D7YVjqqKu6gKXs8JRjN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":500,"st_w_id":1,"st_quantity":26,"st_dist_01":"9bYoS0jcXZsU0MFcGKyqajaK","st_dist_02":"fmILTvrgzdH4k7sOiQ4lGuua","st_dist_03":"xqZFFz7yAvD9StYnQn4GBP0S","st_dist_04":"viW1lmfjGZ9MkVuoHQp8FhTZ","st_dist_05":"USP6qQAkfKXam9mk3MlWYizY","st_dist_06":"iFNY8tUDLuuRgimAPyVdeH9Q","st_dist_07":"tbSWKRQEkryphDF3yMSEFz6f","st_dist_08":"7zcdKztF6xMc8kYceBNa2MsK","st_dist_09":"ZhMR1IASo9Mr2IfH9ggHjO4t","st_dist_10":"RyCFR7tGXC1LOWVTl8FXT7j2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SLhDi4xga2oddNyeSqP4aLI7enx2mrfWDvjzLjlHYkn4COJD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":501,"st_w_id":1,"st_quantity":21,"st_dist_01":"8XPaGX6PEATFDM3VL0L5Cg1Q","st_dist_02":"PuDDSYv8nJ08LhSKEpGFBNpC","st_dist_03":"IrEcQc3cHXSmHexOBv2j1Yzf","st_dist_04":"Qn9tn7XgvMManFmJJPsxmSF3","st_dist_05":"xR1gLpje6zfkQ1ksRzJYJf51","st_dist_06":"MqYDDjbsHTQV2JdJwc0ukqvU","st_dist_07":"eoUe2HeeD7mUTlSp17pJCkQf","st_dist_08":"ESWQgwd1QKDyqG4WHoiJmXcA","st_dist_09":"A4Qw7keQbDyRJxGSkqaxgSoU","st_dist_10":"g9f8IaezMPPEqCe7C9KsGOC8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qDvbJ1z1DCAgwZwvTxDiJsT63CYzhJz7HpFplkr5maRj2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":502,"st_w_id":1,"st_quantity":82,"st_dist_01":"BuoVGAztawnqM331bM93JpUl","st_dist_02":"LKZmtHtDqBJJolCQ7Z0yRd0T","st_dist_03":"CuXyjgy3ag1LOhZYrv84Y5aG","st_dist_04":"taEQ0fNPXwOl3y0F4epOIU8J","st_dist_05":"72bIaZAiKGq89rgwvSvJV7NB","st_dist_06":"YaWmfHQuu3lylDtUllDPGaIP","st_dist_07":"HdBnUmTtyyGTfa6i1FJD9N5Y","st_dist_08":"GZFIGo06ulMS4XrFGOOowqsq","st_dist_09":"IE2rP9wvG6S2GIbXmJcOsEeh","st_dist_10":"YS6L4lFsKgXyKVebC32e2OtN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cOeBGklqdB0F1cwaMRPreyIlcnHVvu9vtCemeZnDwsws"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":503,"st_w_id":1,"st_quantity":16,"st_dist_01":"ZN5fVV6ttGI2kmSrTPuKkklZ","st_dist_02":"pCkPEWKusIYNTNn8W0rMud1o","st_dist_03":"KKwD82e0GI7YjI27Vq2HktxT","st_dist_04":"ctLr792QvWzJHL85toEKbKkx","st_dist_05":"N5FYovwL1wTiaj7Ne0MGbSqS","st_dist_06":"19im66jt1aDnNUVvrrIA3KHo","st_dist_07":"DjXPJsvWNoKkITVnb5KEh9Ga","st_dist_08":"GRjbl5zX8ceGGmlTi8WjWb49","st_dist_09":"r4nFWvlErlZeXsvmGJnsCa4z","st_dist_10":"I253Z0gHmyK1O4du0ryvWM1I","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XcsyjsDxKH2TV0ekhNHQUYrpC42NP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":504,"st_w_id":1,"st_quantity":55,"st_dist_01":"Mdb7rShiivlE6sj0sNFuIgqO","st_dist_02":"ZZhaVps951WG7hCnwpXQ5LmS","st_dist_03":"EQ5qbwRUhjHifM9MsWvQbpZu","st_dist_04":"lWq5pKaR88yraBSfisac1HzA","st_dist_05":"fkE8TjAZC2P4TlPoU9MSNcHX","st_dist_06":"HxkBigXJeamlSyW1txj48pve","st_dist_07":"FrbymJdESwrXf4vB53PkPeSn","st_dist_08":"jCjqvE8oZ9vENkMr2CQzLn02","st_dist_09":"IXiJFAajiXD42p065cfaQNrC","st_dist_10":"NMXJp2g9FupklpQVqYQtmQne","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qlDkVcZinFRQOaR6CDPBaEbmSz5Nnf96rQU0SUNsAsS3tRoH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":505,"st_w_id":1,"st_quantity":94,"st_dist_01":"rTxteTPtHbOKZ2wPO6NJstat","st_dist_02":"eVoL5AjOF4Wcs11VyHuYj2Il","st_dist_03":"72JQXixCTohe8jDXjYgPeHD9","st_dist_04":"K3K6NcViG3uSESwaysn6GWRM","st_dist_05":"D4HyLiuN6ukJUIaLyiBesZMa","st_dist_06":"7Gx72kFbQIg7BsmlgIDmXGq4","st_dist_07":"fGmr69qp60YzEo5HkY0nOTwb","st_dist_08":"n9b3DPEupMMoQuatjL1MQzuw","st_dist_09":"WpQrebgOQZCyFNt2SXR8DhTP","st_dist_10":"CJAGMVeyolgK0qx4W9rc4zR9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GH9TNXlORPG2W1hy2o9xb49loJIGFVjlUOqWuWfQKT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":506,"st_w_id":1,"st_quantity":78,"st_dist_01":"oXNkYQh0Qn2Uzv5VS6GoB8QM","st_dist_02":"qke2L8UgQZyCtTr927xSJoJs","st_dist_03":"XIL9fOprLR5Kn4hHjHWzUTQA","st_dist_04":"cLX4JG0wX4CaOrWCr9w8jXBw","st_dist_05":"AoyLpMYYM5H3yjYWAb7Ymc4w","st_dist_06":"WDfisMd8CDcWkE6cI7tWliSn","st_dist_07":"bP9XYvWEDqhcfRxMVZOKPCFC","st_dist_08":"vn2VAT0pWW3GcBUhysukyHhf","st_dist_09":"dkWquj7qpGKLTMvbI4wfFCnG","st_dist_10":"cVkot4PrgdmPr8S7YOKfQk3R","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sPxAZoHGIuMNu1YK4gfaWtPoriginalJWMwvpM7pWwk5KlSLpd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":507,"st_w_id":1,"st_quantity":80,"st_dist_01":"BgOJfjE9TQHDbBj5NS53FpMo","st_dist_02":"VovYvoO3V2ZQsVoMTQdgBeWk","st_dist_03":"8vyLcT46IiDgQoPpErwYfyz4","st_dist_04":"LHae6bbpIOobhX2TxtiYZK7I","st_dist_05":"BC63OSDfjlTgxHnJWlVxe8kw","st_dist_06":"wXm8TqaycwysMGjVFkVBiLvD","st_dist_07":"fFMJricjcq9HTyGpR8U6hS7P","st_dist_08":"0doupkAvzpoxV2rgnO23I0uA","st_dist_09":"H1SCTCmktT2hhPTNUpfOBomc","st_dist_10":"XkupE5CYQQDSgW3rifmjJLvN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dMdfkrCDMaPfUPQdtYIDd73qVplBbCyxvOZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":508,"st_w_id":1,"st_quantity":80,"st_dist_01":"XEL2ipwPgCvW1CG8ScjQaSZ0","st_dist_02":"nzZZ3cKn3zT5pg5Mozn7Ntac","st_dist_03":"DeMXMlAsxYyegxyURuiUKqBc","st_dist_04":"j5yDrBzvChpCO2rwjTipemqe","st_dist_05":"a76vo0chqKoELEn49ZiMTBdz","st_dist_06":"IaTeUJ0J3COFhozJglZTFDqc","st_dist_07":"YX1nFzAehqMLOf6wmQpnUxYq","st_dist_08":"s5ITy3SKtwuhGBMJgs4Ogob9","st_dist_09":"WHhqgb9j3jTfBnm8y7YNdEaD","st_dist_10":"cgSoiKq7P4OIIuvYXEmsxywF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Owh048jqC9RIdX5NTA8EXNWgY4uiOhc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":509,"st_w_id":1,"st_quantity":45,"st_dist_01":"V59OG8bQTT8hcQADyoRHwoIA","st_dist_02":"JYIieMtinmO32SfiDmXQU4tx","st_dist_03":"cy9apYCGunmn7p1KnjSTvUQs","st_dist_04":"slDVxkumHdHszusezhIJK6cq","st_dist_05":"dy4VLwd16iNgF6QNzkyax07H","st_dist_06":"dOA9yJ4UG4o3tm2HZNidxEYz","st_dist_07":"8xWWAKJP3lQwJjVHhRmAN2XT","st_dist_08":"2MWpudEYZTRGmFk22dES2vEh","st_dist_09":"Nh1XpikaCYkEOw9Z0KsU3UK2","st_dist_10":"lvqXRuXm9RlrsMaeAsrsxnAi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BD4TZYvnYV26N1sB68MHf8xbV58uXFkYuJJ3hpq0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":510,"st_w_id":1,"st_quantity":44,"st_dist_01":"xOCAKfZBh30oH3C5RolVICgv","st_dist_02":"jOGGRtYLqIFlEEvCPAKZczoO","st_dist_03":"7STgGAFRL7qzOWShpSVZbkGz","st_dist_04":"1hpWfZvYQIHabu9yoIY0VYPj","st_dist_05":"PxtYehrdHMM7kyvBKxQpST7X","st_dist_06":"Xktj2LICPLbHhha7fT2PLwDr","st_dist_07":"YFIZEyGHg8EQt4MnJTR0tis1","st_dist_08":"Ihp09Ga3B6sKmpkmVBxnjspj","st_dist_09":"8rDiKEcCyIipAfM7coxD6XOE","st_dist_10":"UOm3Z8dJQ7gUqGqtcyp5q4tN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"F7twgiQCkKWfMDXjV6VSjXxKS5BjPofjpZsJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":511,"st_w_id":1,"st_quantity":20,"st_dist_01":"eVlG2Gbumv9V7DKjOxB99hHA","st_dist_02":"BWu0YuDlKcwbetfW93Nl6XcV","st_dist_03":"pgDyqgMDML8dVYVAuX8MVKJx","st_dist_04":"oJzBY2AFLq2I135jvJHGw6TL","st_dist_05":"Axb3nXXExeGfiRaRTKSkfKmj","st_dist_06":"SYc5VMAuedfjnWu0A1fJH1Jg","st_dist_07":"WXbHODAWiPWppvFo967jjFTs","st_dist_08":"c0I3XXAO77YSYISpcQXHVTIS","st_dist_09":"8YTE5Q47xkAgC3isIEchsvpx","st_dist_10":"L5c7wnXASd1CN59VZXj4hlSt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bqHX6xZA9snc7VJZy8SOeZfHnl8gKdjx5cWqzW49lUI7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":512,"st_w_id":1,"st_quantity":62,"st_dist_01":"LivlO6XykCF59WDlJr6buqPD","st_dist_02":"pmqxmclkGMyRy0QTIrksZLUf","st_dist_03":"hyENFB4Px7zsT7TE5s9beMHs","st_dist_04":"8AlgiQYIA1nkJuwvIGV0leth","st_dist_05":"M6SpiAODlXXKsz8nUbnKqgBi","st_dist_06":"siYOzbrJZO6LxVHvEScJ40Ju","st_dist_07":"ZFnI4ZLE1pWA95IuHd3KzyBb","st_dist_08":"ZsSF1zZX13WA47WtK3WML5Nr","st_dist_09":"FWcYbkAFMcB8hO6w2oHfHuY4","st_dist_10":"CaHwO9IRukZBLpJlYONCnW9M","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LPJgbYOuJZuzezWiNK7GMalvraVxV1QItCuZO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":513,"st_w_id":1,"st_quantity":43,"st_dist_01":"hrknJMWI0J80dJrekIt34D3L","st_dist_02":"YcfO12sHp1QB7WPUwl7g9oBx","st_dist_03":"2ho7BUsahpDmXZds3KKqvgth","st_dist_04":"j5vNRM2pYAqNu8tUBf1Uq380","st_dist_05":"LRQe4AWE8F3tGxJGHcaf760j","st_dist_06":"S170t8RV318EK676t2IFVAhg","st_dist_07":"RRKOPNuZ0E5v6AqV7CMuwJH0","st_dist_08":"eetOdODv79amo4EYMch8rEBN","st_dist_09":"plcrM2ywxzRod4FEeUfwKPe8","st_dist_10":"IRlgImD7yu0x5cNaCqvcSy3Q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vQRPy0NyXd2ErYeSxnHdwMc6keaivL4EgJp76NFGhM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":514,"st_w_id":1,"st_quantity":59,"st_dist_01":"DTxuipofJPP9ySTPAMlvoG3Y","st_dist_02":"RkSIue4x1BBwSeTLAaApFIy6","st_dist_03":"S67s97Wrgh81CT0jYeGTbDyq","st_dist_04":"1aVWQzfl8HaPWUBLmAmCts2v","st_dist_05":"iRKF93Hf5rUyaG3s1nQiLbUT","st_dist_06":"W1SgOiuQtCSzIenuPaEa1qCW","st_dist_07":"WGSUDcdqXDyEI5hF9ycW7Mgr","st_dist_08":"2Bt0nGh4PBbr409yWt0nR6i5","st_dist_09":"zSPVC3BuBfzHV62dlGnKHjNk","st_dist_10":"OKkD4u2xjNegnhkiZwUATiKV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LXIyP61qcXBKdc4F6HkVIbxJExvx3HhvpHCIIbjis"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":515,"st_w_id":1,"st_quantity":25,"st_dist_01":"21pW8UyTPwTaTugbFSrH9TSu","st_dist_02":"uxOCgYHgjXUJATscBgysvPZW","st_dist_03":"3FJxoam9cx6MvMdLL32JCbxE","st_dist_04":"VbW8gvwYwITrf69wxzIuy3Wq","st_dist_05":"MnSgtop1OMVBfBwDjGlTyvEj","st_dist_06":"bZOTvOnotCsI1KZwkiMWXTVa","st_dist_07":"SFs91ZybhwVB1Fxxkfz73Q6Y","st_dist_08":"sag00r7lsXWDKSs4riVoiMw2","st_dist_09":"lgNlKylNGshnTHwNE38kW1C7","st_dist_10":"Ez61mgB7hTKieHM8A5roEqpb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ys2aci0435SClDLHwMxJUWsqX84dKbXqW4BD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":516,"st_w_id":1,"st_quantity":60,"st_dist_01":"pOnSSKEvPDXFosPYlBO9UjAv","st_dist_02":"AsXg2kQJHhZDryqmc9cI7e3e","st_dist_03":"rpuGiddtoqAz09jO8lgInox0","st_dist_04":"68Ij7zdBXDnGfe7SyitxX7kn","st_dist_05":"NWAQsF4mE1vS8rRmCLeQ05P0","st_dist_06":"s9ofbvakv8Z0ogowJni7bXHc","st_dist_07":"ZbXbGhMZE5MznkEUPmy9n4O9","st_dist_08":"TLO5ZVNjHtsDMwMzduTXwo1d","st_dist_09":"HKKzULnZfBSgzv3Fw8vU1S04","st_dist_10":"jaaourZaP7cFAIO0ya2fpP6l","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UKBHgJhfGBsxMmLeKaF50iJrMMAf8vNOJ70TipFd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":517,"st_w_id":1,"st_quantity":25,"st_dist_01":"6Ivm3A8VfolXakp9lZe3Rm8d","st_dist_02":"1kYeezOJFfqPeJw6kuekTOOf","st_dist_03":"MSuoTUZvdJSMl3kjQtHhrBDL","st_dist_04":"F1ED3aTCet1rI0RlMdjuSdJX","st_dist_05":"09lupWYK9hYjbmnvITXLSjcO","st_dist_06":"omAGSxzBxBPow61GQoakUbGR","st_dist_07":"vrIYvHIx5zOyR0jrwMGSJwX5","st_dist_08":"6H3QHdjg1IMcUNIiAr50w2kg","st_dist_09":"8yi4vKnmuEXAWm9nrx0eGDG1","st_dist_10":"2POnUFfVwWnly0Gd84iZ48cQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IzNvEZ7k7PvFLj4yFMvRpTyYhr8DDPAiHvkRRHuOsnxzG9x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":518,"st_w_id":1,"st_quantity":50,"st_dist_01":"z1vd8qDQaBQJ99HT14dH5Vbh","st_dist_02":"ozwiFo57eKzi7IzeVBfOvpfK","st_dist_03":"hEvW8GF6BArEKpAr26MqmW4B","st_dist_04":"A3FU13tjJdSMa1Q5fzjIgcXd","st_dist_05":"IbgSIUr2qlPrK5bmt0HmTn71","st_dist_06":"yyGo1ElDz9ptCBujzwXstNHG","st_dist_07":"JU2OVqUTu29Mf42XT33DnuQ8","st_dist_08":"xb3AY5KueKqPUfkWji6yCWLB","st_dist_09":"5wHytKR8mxevpZSi0Fi2eAAs","st_dist_10":"gepaHIURaZuePW2RQoAUtPXW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2n1ktEXqwgPEC4qXxavaZ7Pb8nLue9ChHZ1qQ6lOs70I4De"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":519,"st_w_id":1,"st_quantity":74,"st_dist_01":"kMsHGglxn5l62ACGKh0xDBR4","st_dist_02":"lhyDJazPvjBFDnKjmXyaXez2","st_dist_03":"7vqyTsAmv0PaLVZwGJRr2ii8","st_dist_04":"OpeZueRjha7GcXcw0qvt8kOE","st_dist_05":"aewBIcKMh5fRYLTfPQkiTxvR","st_dist_06":"64vBAOUlVX9QUieesCWdHeQe","st_dist_07":"6reacxznxqBoybqJPWkHDBrC","st_dist_08":"5XXwwKjqjQFyLZk0jMai3Ttl","st_dist_09":"5nq2ZGPDV1M9rv9qtJ6EQkbR","st_dist_10":"Yi8K6u8TERrxMvvxaJ8zlbFg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MrfFGZDnevEtE9yAtWQRbkmd5qlIsjpQw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":520,"st_w_id":1,"st_quantity":29,"st_dist_01":"1Fs8hrvdiv1IcDnUZuxzIGKn","st_dist_02":"5Hf81UhffxUjWxF2JB4kFqE7","st_dist_03":"Jn2DfVvRZOMRyaz9sV0ArElL","st_dist_04":"mKV7LRYrPmnzmxeiqUlZRcdc","st_dist_05":"wc9wZUQZM1arH7yvYXuKZoI5","st_dist_06":"KmLjeGf5M9VkivN6YlJhoGBT","st_dist_07":"5GDM6GgTX9mvVMCS5setXSlw","st_dist_08":"kj1EtaI51gya6Yh1fClDw0eU","st_dist_09":"IVMYRKAs1SORaXn3awyMzm6W","st_dist_10":"6Ev5TOpobxP6gMJzp3weYWE7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lnIyMlmVbv9ELbB40E4CcFI499irEOfrX6BAM5idBQCi5HfHv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":521,"st_w_id":1,"st_quantity":33,"st_dist_01":"CI2OvTcPxx9f5SisVMasTdQp","st_dist_02":"aP0s4YlEDspvpiAIVzQudm9r","st_dist_03":"f8mmAUBe1w68diC5QeB4ahuD","st_dist_04":"v3xlAS3f9WFN07a6fZNApplt","st_dist_05":"fTQWm4RdYA1vbxjz5Xj7amI5","st_dist_06":"pXmgrInI4YqzvQv8Bown7Acm","st_dist_07":"aHyiLmiGjlLAQPEANxpPtpIB","st_dist_08":"T8XdBQgszE9Pn3sCA7FyJOw3","st_dist_09":"kRZZaAobn3wvpuBMoIPuvK3d","st_dist_10":"6pMKnfo7LFnX2dUDECgMn3bK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KqWUwdeybtKWCP5akJ9e23HfKZHpJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":522,"st_w_id":1,"st_quantity":40,"st_dist_01":"A2ce6bjAiQDK5Jf6h5A4u9bD","st_dist_02":"3qHOoSm4BlfdYAFwB5uSrIBW","st_dist_03":"NDz2shJsV6d8OoUnD4jyIQsF","st_dist_04":"foPOefshEYL7yrcddlGKTLZO","st_dist_05":"TiiOjUD7XBJQcAU1GW6SJXBp","st_dist_06":"X2dGYO8cROTPrtiqCaWGlrTy","st_dist_07":"4P0H8IdQXmeMfFfIXmDm7ZL0","st_dist_08":"3tBLja4ckWWC56neUgOaTD8q","st_dist_09":"02YPFoDYQto9ADjGCr9CjghH","st_dist_10":"vqagJ7dHQEBZOh5Onb2cN152","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KG7hWfKancCbl9k8mrN36TXIqvb1jnDEIwdBa3pmMa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":523,"st_w_id":1,"st_quantity":69,"st_dist_01":"lIgnduqN3R0DHVuCELIRv2P6","st_dist_02":"CbOafJE3O2p9T8Vl4ddS5y37","st_dist_03":"h9qiB68zgTBCMb4d6pI12Frc","st_dist_04":"I9MjoyRknEVlsRMXXtCagLqc","st_dist_05":"kgbbUKD4EoTJp1gq6LOIOeC9","st_dist_06":"pzdcXvIQsfz8E8UUVdtIJfNv","st_dist_07":"UYOhpC1Dmq55NTXtjtwtuwEc","st_dist_08":"GsLJ3b3tF010B5xwT14sgL87","st_dist_09":"HTrcxv70NHrIIU14iJmMBGqI","st_dist_10":"PrMMYfZwVCfG6c16eCnQdKNQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hVzvizU6UlFJ20sjT7fRXFvhpytVOgAvcwu3JB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":524,"st_w_id":1,"st_quantity":31,"st_dist_01":"eLoZNX6OgGQg1RqZfS5XhY2w","st_dist_02":"1cKAmvEk2nEypRr6SAz2DRDy","st_dist_03":"M2mrzNMiAv0sLYrV2UaZmCxz","st_dist_04":"wChVOIpItpDKHdzk3DQZB7xy","st_dist_05":"Wrbo3LNZsLUDWeBeXyByDfwN","st_dist_06":"i7bKEQpwtpbsQkZhHnp52Txo","st_dist_07":"Fpk0lHM5b31ZSP6JywCLKM89","st_dist_08":"StsskIXyHxziRHX3edFJjWed","st_dist_09":"ooiyiJtObbkRFTvXRfNN37Lx","st_dist_10":"JqAyf7D2AI7qVo6BYbdtGAVl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vYe0ZyqtUiyk1uPinwnz1ljxr6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":525,"st_w_id":1,"st_quantity":38,"st_dist_01":"hdeuRrjFicomBbwipd4FPvxU","st_dist_02":"1j4Nhb6k5HvuebhLf7G4VnV2","st_dist_03":"9FHLHlTrJeYoTbh13cGpnK0R","st_dist_04":"ILCV8tQMbu7vTKpMuYdgyNw7","st_dist_05":"eCvV3u02uSkDrfbhituVhKXw","st_dist_06":"UA8xa97a2nng3t56qxPq9rAo","st_dist_07":"uNMmUZ7EVrZyWiERwvHla4l7","st_dist_08":"2G4qPvM3eVzslycjSuSt4LvS","st_dist_09":"2marZvoq97uSh6VOjPfQSXxA","st_dist_10":"uenHXFTTbNqJ1Glicgj86IeQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SxTN4fBYtuRc5AbeU5AYvNgWsiPdYtEKL9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":526,"st_w_id":1,"st_quantity":32,"st_dist_01":"4CXR6fL8dhT7V0mhFIM3E948","st_dist_02":"gGYlJWQsPwctK7BRJ5uzUTHo","st_dist_03":"iALt7I48THygBzNjOdusoxNO","st_dist_04":"3gulkG9nt39YdnSSHhaYTyYA","st_dist_05":"yy82c3DfuhUHi3HFj5Hwh4iY","st_dist_06":"jiL1yQJ6MZqVVmuP2rmHzBVZ","st_dist_07":"qplcir13tJJ9TD4c1k4TEjkW","st_dist_08":"lddx0tKGD6qeUCtWrXTtOh96","st_dist_09":"92EJhxmcd4fOaebMTFDulK9h","st_dist_10":"Yv1vJ87OHgAEaRtQPDIionF8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kGZwxBf6AYOnZnTujeLpCIniVKzX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":527,"st_w_id":1,"st_quantity":67,"st_dist_01":"1lRtpAM2M8jhtndf1TEqFPVo","st_dist_02":"AxUTvDCL2PM62BbVvOxIyh43","st_dist_03":"BBqjNo2ohOQfhds3UhoOjRkT","st_dist_04":"Kkc8HXtcMX6QZSse9RxE0IPZ","st_dist_05":"1husnoF8bcaTwHXPWZV8KjyC","st_dist_06":"7nat9qR2OZZdRAB9g50RWWwo","st_dist_07":"TarSkWjw1OIDX5QT5D4E53i3","st_dist_08":"mTj6oZ8Lry7j9lmzlWvWVIJY","st_dist_09":"XaXHS9qSMjcN7zkXEOs0qcXC","st_dist_10":"6G3EggYOTfIFp1ZlJVCbgYP1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GpyW3idA8ybJC3EbUeH6nKH9original2a3U"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":528,"st_w_id":1,"st_quantity":41,"st_dist_01":"ipueAB4QGUveSNjXvF9cQjxT","st_dist_02":"lfyh4Fj1dPx4kNfJkp1Mj3aT","st_dist_03":"rvwlVQW6qdHAs9UqqtXcqIfk","st_dist_04":"1npCofZ8nDbrGeJXw3V2iVED","st_dist_05":"q04VLVgEpZAI048VR3o6emNr","st_dist_06":"62fkbGqikgwqu77GJvosiA0O","st_dist_07":"mWHhtiPtRQkRO3aYMdqtQXbI","st_dist_08":"SlGzcaLVPyGNYjVwYz3GBMsV","st_dist_09":"xZTSyA5QoHP9ZM3DD222Ybue","st_dist_10":"9RqbK1ikVITDzwaVzsXCMw1Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5MbB13XZMP94Tp9dOFDucXPoaMe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":529,"st_w_id":1,"st_quantity":32,"st_dist_01":"CUbx93dcPTXqkqhzxkl2kUdc","st_dist_02":"6V9O5ySrHPDWS070WrPVuf9L","st_dist_03":"ACPOiuvIHlmI74IucqQHrL7I","st_dist_04":"kRoJVlgV2u7YlmHAyhVlrhkA","st_dist_05":"qlyC9bfw9MwnhvnzSjQLlJMc","st_dist_06":"PFR2KLbCFH1Sln6huE9qd33k","st_dist_07":"Gt4HMWKEqV3j0AJXRNQIZCw5","st_dist_08":"zANrUevf9410uAizqUOSg3e0","st_dist_09":"hmG9Ey2d0GKmDxModlLqiZ65","st_dist_10":"J3a74qMdRj4TEoeEApGLWVHi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8yAXaR7lwZx1Z5eg5h9Epc6ppvR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":530,"st_w_id":1,"st_quantity":52,"st_dist_01":"Unb4UL7xv6FSC26OhdBHKoFD","st_dist_02":"dmtRrdl4MFqXPzxJRRW70mJn","st_dist_03":"xLQhK0TsMiP5dI9PIXd8XwVN","st_dist_04":"RhgpaWyGzkyfg0vMDg7WovtI","st_dist_05":"XJ9WexyXXsjYGGMV72B9CTZn","st_dist_06":"pFdODDG8DxA7m04LSmZCJakM","st_dist_07":"U4yhcAqnvFAcY93eocAyzW5F","st_dist_08":"9JhMgjkdOi0iuYeVW9bZjwxN","st_dist_09":"QT6MGotvIGICYAOcwnSPJwl2","st_dist_10":"As2kKAiWZQeGdePmjZUilQtQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HHXm7O4oeQ3XBo4Ln2eC9nPdt5ZlMQSemA9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":531,"st_w_id":1,"st_quantity":68,"st_dist_01":"Z3ZNi0UWBvUHB7pz9GsVPrH9","st_dist_02":"lIkHnzbjVDLybzhPOdfOvDYT","st_dist_03":"Mz2jXX3cOTwyk8xOwZdRS5Bn","st_dist_04":"fJ7mDBLy6Hseb49iiVZzu8nx","st_dist_05":"jememHYMg2xJNbYmZMcS7us9","st_dist_06":"Jn6z3exON0amhIKLzFNwpmTG","st_dist_07":"YuB8U8EEAZVir5tO6OMtKp6d","st_dist_08":"Zfz65KZevVHaB3P3FTJlpcyQ","st_dist_09":"N4zP4WiB3eIKjp7qcBOMswnA","st_dist_10":"AFvaeRNVM43Sx6b1ecTDC40b","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qoriginalowERd5KZeCRIeFgk2Y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":532,"st_w_id":1,"st_quantity":28,"st_dist_01":"a0HW89qq1IkJJca9E5Twd6r6","st_dist_02":"ZHOdaKTslyLIriAudqBrLA0t","st_dist_03":"PhuDd3TRk3CeLCKk0DxNolio","st_dist_04":"Ho4wKIxilS7jqbQNGqJhOtG4","st_dist_05":"MwItBsykn1nOeZO7TXa1QXUX","st_dist_06":"28hhluO3XoaO8F6HvzbZOH27","st_dist_07":"0WzkFpNM4uuBGhL5zBRhmB1j","st_dist_08":"uM0WPfrItZJJRtchN735G1v1","st_dist_09":"XuE506xidVovcdWVBjVOLxJo","st_dist_10":"cRUspMXBphRFBZHRxaRZmdcD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ohBbdoqXoriginalrdSs14Xu6h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":533,"st_w_id":1,"st_quantity":89,"st_dist_01":"9DvbsfNFtPLRyTG0Fyay2Juw","st_dist_02":"Vnun4vueVbgAfu4VoWeZjhGF","st_dist_03":"4JOOuGeHFrpTuAOJV0hhKFEy","st_dist_04":"kM5uQ3ShudvaL4RPIN4LFWfg","st_dist_05":"ti6QLqWeuum8pfyuBRZJ9XaL","st_dist_06":"R61CX01m1e3jxBS6q8cAIAzd","st_dist_07":"rSM7GHaTX7vJeiCCBtfBjY4y","st_dist_08":"Fumokjp1ywRaNZju60N4XvO9","st_dist_09":"PB4wwEcB6DulAK1UpMQNbioQ","st_dist_10":"fjLBh8B0oSNVFmUdLzNMdjpD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XE4cnFDkVAytA1McmoriginalFI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":534,"st_w_id":1,"st_quantity":10,"st_dist_01":"cy20NWMHWHU9bi15PNFZoUwU","st_dist_02":"CwO6HRW304VfhbzXaYDHGEeS","st_dist_03":"VGos5danQ64UChrsK5GuNsIH","st_dist_04":"6IDtwWZot9Gg5psxKpnEPzbj","st_dist_05":"RVENpNVfDUtJSumnuXpVaeCB","st_dist_06":"GhWJXoPxQqmswODz4xXbns1N","st_dist_07":"1gV7Rjl1Z4Dutdgu8KsvQPzS","st_dist_08":"9Gq8cnl6cx4fdfrl9hQWduJc","st_dist_09":"VmlVj66l0F28PpHJ8V89YVYl","st_dist_10":"pdnfZ2M1yL3gywZt7zYTNUqM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9lloriginaly6ZRVsTFYEp31OrC2g27dfR3e8c27h9ukWzZqv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":535,"st_w_id":1,"st_quantity":69,"st_dist_01":"ebDauvkfqZuEr9eRJ9uJ6Rh7","st_dist_02":"PSYZnPtwIK184my3uAJ4uf0W","st_dist_03":"sukr4k0V2T4NSB1AFu2G9qvd","st_dist_04":"AQHomqTsnHf7x3tFPWZ6TYnv","st_dist_05":"19IPqqbrk15wIKCjZ77pcSzC","st_dist_06":"1vkPim3EIwkGf0aRRDn3xLYo","st_dist_07":"oFxadg6oflg8uI8fJFNDWaVU","st_dist_08":"RLkOFDJOYN9yxpwHPhmb95sa","st_dist_09":"6LM1MPWSJ4SNUrxB6kXeZAkR","st_dist_10":"v8zZT8WnbX36ngKCtaB7Wc6P","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Au2ZxAHOjxhtS6WbInyBPEuTiimkaia7vTOf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739238,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739238,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":536,"st_w_id":1,"st_quantity":28,"st_dist_01":"NboiKwMPHEiFhLPiytZbHaYg","st_dist_02":"PNlxtIbyXNW7nOG8LkYT2lR3","st_dist_03":"eYjYVhnOILyuK7iEM8ekl263","st_dist_04":"KlXiV6YnSsLKOTp0kusJ4RTC","st_dist_05":"VYHi67exZLkaYvCT9kDeQgbV","st_dist_06":"8Ekd6qUaM1Z3Jfd1SygSwJvQ","st_dist_07":"4XukWOT4M5N0DkILvxjkajxV","st_dist_08":"q9h1onw0LnUgid8WuKiZWGMb","st_dist_09":"Pyb3kJ79PLeAl0pBxrTnnMkF","st_dist_10":"Qp9J3qKreb2dlWkX8ZR32JJZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Du2r6Tc56b3GAEhEzygXn4n9jKMAd5nb8buMyZqFP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":537,"st_w_id":1,"st_quantity":47,"st_dist_01":"TIs731ikbLu29ugr4fnje5fh","st_dist_02":"WAXYMCHoqR9NMw9AcPrfC81I","st_dist_03":"9E1fNuGe9ZlaRxenZJzYa1X9","st_dist_04":"NibrvXyHAq2mfzd1FZaktQrs","st_dist_05":"LOFrxOkEFBORjveNbdiiGs8v","st_dist_06":"pBdEaVUopwStfYSJX3QsiM3S","st_dist_07":"9q4HPDNi5pEks3zckzSbP31X","st_dist_08":"MlnLQaqMHKMb54wixQPAdvFy","st_dist_09":"qaViEt6KNOoZM8kDmDRPQh7H","st_dist_10":"zsfLa0CrWcCgmSLF8uVSS3Jb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"On1hQY58UqedFzOGkIy3j7KxeR55OYJ6ru2g5Zmd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":538,"st_w_id":1,"st_quantity":14,"st_dist_01":"Q8VsFMQ6gtW5vomJpCF6ibQW","st_dist_02":"11j1zkcudKu8i2eh52HSzf9b","st_dist_03":"NUNpW36WHFuGH3UlXGf23AoR","st_dist_04":"pNXAzZGixhoxmWjr4X0yzDZG","st_dist_05":"jB0MYRclaI4wvcEyV04rk0vt","st_dist_06":"XVKkawXB92VL8x9fBzah876J","st_dist_07":"l5g89yaZh8jOVBcngYCH3z1u","st_dist_08":"6tmG9Jhr8Kc4IxBBP4VTE5y0","st_dist_09":"gijTpO3HWp9Hh9GRXRYgscme","st_dist_10":"avnX4Eg9gfjWH4K7ISalaMfC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oN9DLVSwRj7GesO4TOJyU7XMwzTqd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":539,"st_w_id":1,"st_quantity":60,"st_dist_01":"RMkU0PTbU4c93Anpa7GedUea","st_dist_02":"rMTkkoVIjqynwH3nHbKKKC8o","st_dist_03":"hoAqVn3BZHFKK3D4yGrhhBe6","st_dist_04":"2uQp8VzHXYEdC1YpI82ajIrv","st_dist_05":"SrYOO3Y0GhyxEcet8yYE4HMU","st_dist_06":"oYWzG06wzCBsP2JP4sbBAWQM","st_dist_07":"8ud4l7VI7gWSn6r7pJfHTZIa","st_dist_08":"Fxh02THlpESz6L9OVKVj1tir","st_dist_09":"6FfCtt3lCRKv0Tb9IvqMPF4W","st_dist_10":"moeXqd1MHHAxgIgBQNGv4M8W","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"q97TNRLASqq1k9OHfkWzxkpmlLN3UxeCkPZbc4ENVkYc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":540,"st_w_id":1,"st_quantity":93,"st_dist_01":"U1Vy1frEzvmwe35FjwRZiv0M","st_dist_02":"4JmvrGCQJMW63VHza2kupqbq","st_dist_03":"lqOrSO6hzCweq0s9sNTSc0mn","st_dist_04":"lWSBVMiC1meYQsRsslusSnIi","st_dist_05":"W5WFvDjlk4x66ENnxpzkyBlp","st_dist_06":"cN4zQcIsflgopZJVbVFjlLX2","st_dist_07":"1OxlM4DAtwPEk5e32ebBRNf9","st_dist_08":"CotKI9qEXw0afda1M0kwIWZd","st_dist_09":"L3V4q9zp6jevr01pqnycMI0D","st_dist_10":"pKks39QhFVDptJbzC056fvRk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"C04JFkO5pphIdnMh0rkBQh53VNlybqo6Df"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":541,"st_w_id":1,"st_quantity":10,"st_dist_01":"qGaH78t7mqYV2yXROawJKcA4","st_dist_02":"pBLJE006ox66pKzXuG5IwvZF","st_dist_03":"8W4sIBZRrbiULpIZCu0m0t6x","st_dist_04":"H9eHrme8QnHijhiJ2gEi9cJX","st_dist_05":"huWJfvHOXoy8opKFqPmFSLAV","st_dist_06":"Uet4gsdnuVzO5SOH3kULKM4w","st_dist_07":"qlPHTxNHYioElofp75VwC0Zb","st_dist_08":"xucmW0TMIP26TAYhqeZVSzja","st_dist_09":"FVuDgUXQFK8U0Uq5p24OixUT","st_dist_10":"JIU4aCjBFPi44av5ei2WDN2d","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"knyepDooEP8IckG7CANhZlHu3boMl2IdXq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":542,"st_w_id":1,"st_quantity":93,"st_dist_01":"4HBNzoEamzqbHzF2ugHPF0Zi","st_dist_02":"nKsE1pouEGD5tLGe6QAao6ta","st_dist_03":"07D3VgVf7oz7ldqOYFqfvkp8","st_dist_04":"UPxNvPkz5o9hWM2xJfaiZ4uW","st_dist_05":"oRr1DumThcdxtNo5NNQ2dP59","st_dist_06":"habEaw5faf8gH79sjwGCAi4r","st_dist_07":"ZEcMfoU4WuOqdwWkRh7hwtw8","st_dist_08":"33R025GFugXiKhpu75m1GCRu","st_dist_09":"fGV12qYFYfTndsmYDNSHWDXH","st_dist_10":"0B27EjasNWIt9mhQVc6dl0E8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tEiVX2KPDCglKrLQFRv74JSTexN3NKwwQM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":543,"st_w_id":1,"st_quantity":18,"st_dist_01":"uAgBtDVRlj783kGkijvLGb5B","st_dist_02":"2LJyWb0AfMbSgAgvWFIXHKkF","st_dist_03":"QTdADH2lHVNlV1xCjdXeNvrV","st_dist_04":"NnS4onmkqKtbwUpXJOSCGccV","st_dist_05":"IUagTtgnynBBfhZ1alUYV5dk","st_dist_06":"Vr9rHJmSJoaudAKfuTpGLfZ4","st_dist_07":"cUWw8ZmAdNcI8OwDx0hUWzkY","st_dist_08":"iuTYggbEi5W6gpwAVrs9G9EA","st_dist_09":"CaHz2JxQe3JtswC3im2potEF","st_dist_10":"mKpNqCSEZ0MYyIQ16940uWKN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"F6RefrNstZjLaHjojaTJoriginaln5Nud"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":544,"st_w_id":1,"st_quantity":86,"st_dist_01":"d6iRnT0u9v7pe4jPEkVxo1TD","st_dist_02":"TPhzNMO8v99LMLHkzuazxhpv","st_dist_03":"L4CqAe0mPyhaiYeb5rFpjMYr","st_dist_04":"c8KmOKYTS1vrM70H9Zfx6gKn","st_dist_05":"Mh43CPclPoFBNkHBhSK8Y0Mr","st_dist_06":"bRE0iCdYz8WJqjdHQRLZ3gvU","st_dist_07":"84Za4er2a2NtOiBCi8qrDbLi","st_dist_08":"O9ND1YaJ0pMLVTSxjyLXbfJZ","st_dist_09":"pfVg03ftTGgAhXWRJsGDuv33","st_dist_10":"ox3T0XjKc9FkL9thOx19Dbrf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ADbum7sD8O5QKMKPs33UbsXdpZahnWNZv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":545,"st_w_id":1,"st_quantity":49,"st_dist_01":"1ew1JWEHB3f39XPObIc8hsXE","st_dist_02":"MwzlVnIOvcmFIB543e4T9wbf","st_dist_03":"blX1eaAmDaRVDZMz5vkkkQFZ","st_dist_04":"q0TYuYTkwsJAft1Va69fqVgN","st_dist_05":"Ua67uK8wgsCmnmYXjkxXB22e","st_dist_06":"dvrxz4eiFDCdkvMdNeIJ4el2","st_dist_07":"G98pAxK8ZfgtltOLwBa9WtEV","st_dist_08":"hZn7OUNcZmJmsVzcVax7OPfc","st_dist_09":"AZuwhfawKmIJtVXpm9F9ZXSv","st_dist_10":"zV74c5HbLVUa8Z0qXVG6Z7pJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fXfzaGSMuFipxCxQHs6kwWUtm3iMszkwiUoriginalYn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":546,"st_w_id":1,"st_quantity":86,"st_dist_01":"aMwlxVPhohNqjibFFp8Ture6","st_dist_02":"Rm02Q56xLVj1S6W2H6dRMvtz","st_dist_03":"yWNSCVDHGckXofustpc9G21A","st_dist_04":"RqDG9HOjQVLeSBL5E5AWRvN3","st_dist_05":"juTy62xwroDcOKZQz8BDhs1M","st_dist_06":"IHCPszSUF4q5w5JqZUiYYm4n","st_dist_07":"a9MYAKa7TNeZJPGa9DQhXanT","st_dist_08":"8FlFlG1FOfyLB9xC1Ps8xdmS","st_dist_09":"dr30wQFJAZDtvk6HcZjuvTVM","st_dist_10":"1QL9xJkaJACSe0TkktefAvsG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PjFEDn0trK1nKTv8ViYDQQVNvpUAxSd5kwv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":547,"st_w_id":1,"st_quantity":40,"st_dist_01":"sqCSpaUhiRzUbbhMzvgfxA1D","st_dist_02":"sdkngmrUqcOraTDmwBW9DgZE","st_dist_03":"ksPSlv4CZi3GXRC7ZCKZJDvI","st_dist_04":"zXF3fTXBgYPchyo0dDJ55hRG","st_dist_05":"JDNRM6rVaMP1iE7qPv6amXjs","st_dist_06":"YRbq05UsxJqeF6npsxqZRZhU","st_dist_07":"txOgBl1JNh9X4j71FAoYkhgt","st_dist_08":"D4KsKob0ZiD68EYgAGEWdhxF","st_dist_09":"jlBCVNYiZw8ODepNZcXpEIpT","st_dist_10":"LUHoI5PKeQxbNZbSs0ILq7xM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"U6b5Jwvtjy2myS2LGLEGNzFklkSEojBYEzvCz7OcHtyPi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":548,"st_w_id":1,"st_quantity":64,"st_dist_01":"BLQw2DUKOAnkL1maDJYvzceo","st_dist_02":"5WCuYtE42gBORHw4l9zVkFQe","st_dist_03":"zpxoRgFTDVdTGB20vzulL9bR","st_dist_04":"exfI0QUo6YHpPjXbcFjRpTy8","st_dist_05":"qgP2dJPfdkKI8LB5sCOTHrPR","st_dist_06":"CU7DjMAxTBh746S7eMIgtHWL","st_dist_07":"YAO1jbjDXtI7xrowXlywTafw","st_dist_08":"WuBaGot8J9ZNfxsb4W2gBc02","st_dist_09":"XbjAS8s8FlfYyvUwkeZL81TU","st_dist_10":"77laCFAddyTKFBYTwLtdKPu4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1zSCJaQ3U7dW7IlIsYPcVEDgQTYPE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":549,"st_w_id":1,"st_quantity":87,"st_dist_01":"fmOMlNQWc6v3M6e4ac6jjGt5","st_dist_02":"jZ9pmKRzs1mlzi0xZTR3EfAd","st_dist_03":"onK345vt7n1DP9J3SrkIqTAi","st_dist_04":"SmonvaLc17MWDaFFmyLFBjas","st_dist_05":"2k6ihLzMuzqH9QiWz0pl8WrA","st_dist_06":"zobddaIzClkgJ3z78Z49nXUf","st_dist_07":"Nn8v6x5cBNLIP9X7BQCTtIXI","st_dist_08":"19RNVhlwrudP6KTjbDG4v9TF","st_dist_09":"BP12SiXp5VhmcefaBvxrQOc7","st_dist_10":"aMB1jvaN96mEGjkR8vHcw8cB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ilIa4nmAVzPqhpWAWtMA0ppFRh5oozE6iB1M0QnGpeu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":550,"st_w_id":1,"st_quantity":10,"st_dist_01":"sQ10ewPeTGXcHkmOLfuUcbYw","st_dist_02":"BXDRD5ph4EqbamUrvI0VwHtw","st_dist_03":"0Y0SCIDV6YpowLtKOD5o9Gaj","st_dist_04":"3tIYytTQsjpuCEGBuWxhSs8k","st_dist_05":"Pejr7W3BaUlkdeZDF7AiJ23V","st_dist_06":"8h4imeRxYFf3mysXjKJues6E","st_dist_07":"d4SVq6iRmR1t0MbLh8hNjXYc","st_dist_08":"sQxIjjb4m3BiKRORiI7yYbse","st_dist_09":"vZ2kzyr9bJKAih7ll0Er0McA","st_dist_10":"BsNim41xtMcuEY0mO3W7qagS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tX5doriginalyEuju8JVkP3dtXcSKk3YxaVhnZE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":551,"st_w_id":1,"st_quantity":58,"st_dist_01":"ZBgkZDayIxfgI6XQmTTouDNA","st_dist_02":"ZnPll0F78WcBTKOcIaNxn8AE","st_dist_03":"eYtmFCt6yhR263DUuIogh9oN","st_dist_04":"bzOms6c9oxD7IfaPDzMfXeI4","st_dist_05":"iDSZqg0cddTbsCWhY9qCs179","st_dist_06":"j5mq5xkcpiWi5bUvzkSQvQCB","st_dist_07":"JN7cwbvPBdQOkjIOzbuo76qZ","st_dist_08":"CcAYC8l9Kw2X9xXJzdUK7YSB","st_dist_09":"9LAvRfmzsJeyOxMceQmXfSdO","st_dist_10":"nA7RrCGZbDSiO5n1rUmzaBXd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5DuPeR5nNqovtCmZxtcedf017zRo0xlCVqGEEheFl41c0GOoe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":552,"st_w_id":1,"st_quantity":35,"st_dist_01":"MdIF4cpfrRGGt6ZGel87JCiO","st_dist_02":"be7qyMz0XAoLUOITUDpSvju5","st_dist_03":"H5EcvIIwGEVhsky2y2YzN8rJ","st_dist_04":"R0BNKXIBQgqcp94MBKmjqEDd","st_dist_05":"6b95pVyD6Rck8ySPx6OWCs90","st_dist_06":"PZeFwoIMbemySVeStvKDLOpF","st_dist_07":"URtAYtV9ZrW6wyy1lIbGWjGp","st_dist_08":"HVFjUaxBkM636Ji0OQHjRX5e","st_dist_09":"DBjp5dWroBiKHgbgXmnhFiEq","st_dist_10":"n3prtOrUkvVU1Bn8SAFaDnLZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"abGoBihaI2JJvAc8RDCLr1wuQUfAwBoR5mW4jaH0oIy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":553,"st_w_id":1,"st_quantity":80,"st_dist_01":"UxF2gjAaynHzZA6BhhwTXYhI","st_dist_02":"Ks62IGO31UdGioEiJzoTR6yD","st_dist_03":"3NayPPyTCdq4bYwRShBs79QA","st_dist_04":"WdYZNQq1R9rTMqIVE3gqljCx","st_dist_05":"4Y6M3QGejFxYF9DfgjXKf2Fu","st_dist_06":"FLzhsPD80x9AgewoOvpPIEbL","st_dist_07":"TTct4jpc68kKPXWaGDRzd5Ja","st_dist_08":"wKNxJFBMg0bCklRhnLDGWIWl","st_dist_09":"Kz5w3QbDnM3KhruDAq9Z9EIx","st_dist_10":"wMIY5i0NZ8SxjZpXP8Kzqan3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xjfvDe7eOwRhXjM5fJ1HBHHkdAf8jFM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":554,"st_w_id":1,"st_quantity":16,"st_dist_01":"tZxD4YcGNeDzhRK7l65OVyit","st_dist_02":"pCsFTQgiIT1UzUfrfHVOB0Bh","st_dist_03":"gahbaURmMkzJxWNjl9f7eTwY","st_dist_04":"N4FfrbNTAPFh2JjZ2UIpEzvW","st_dist_05":"v3mOxFHdph97EB9fBK2xmd6L","st_dist_06":"qLIQGW8DtHVQbFelGhqlinmA","st_dist_07":"gvmfWpL9johAMSV2CMUivgqp","st_dist_08":"4GftokzzN0Nj40fWz8pdYDdS","st_dist_09":"SVU49t7up3EIteXaE1Mg1LX7","st_dist_10":"ZL5zVMsXLyVvFZ0Ng3LotXAg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XN7lr5BTzbdIT3LCIJOowYaknLdSb1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":555,"st_w_id":1,"st_quantity":85,"st_dist_01":"6xc3BpU0HigXSblkC30EIDmF","st_dist_02":"EDXv8fHNmR2yL7FBjOoqjaUB","st_dist_03":"rXoKHOon2SxohvdTeH5IXtsu","st_dist_04":"zLuuaffF4CAIdDk3sVv42T64","st_dist_05":"bERLfxR57R3eazaJrUUbPINM","st_dist_06":"1ZJiE5PutS8Dg68NeqDhjfvJ","st_dist_07":"v8GH8weIhFVFBrYRTbw1EP81","st_dist_08":"DYTPqwty0lSQ4ZB1TVlVPJgP","st_dist_09":"FTuHHTy5YtBLfq9RlWuyduom","st_dist_10":"gBk6HLRApHbSAqiP7FbbG2r6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"M8EUt5sozKbSc0bF5cQYB7CrFmkq7GKjmy5Mi6TrNwIBeEhY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":556,"st_w_id":1,"st_quantity":89,"st_dist_01":"446sbNTi2Gs2hW4EdwfIvN3n","st_dist_02":"wj53np6UInFXMSmBA1VPyC6D","st_dist_03":"g0PhSQomS83nRZXBJMakjSiL","st_dist_04":"yfaaNgRbgSGPgjMqa0BY8ItN","st_dist_05":"Uv4dOVnmoJvM2GwZA4VWxWbL","st_dist_06":"p6JFEQzALl1sYl0rQrNev2rl","st_dist_07":"2MU4yzeh14XqF5Mg2x9sMNmp","st_dist_08":"tdskScfDKvF0J1ONNijE2299","st_dist_09":"eSpvBMXPS0G700Z7q6IB7s9X","st_dist_10":"i4wq9iLUcBQONCrekev7AGh5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3zPZy53rPAvO4IFkyV3qQrxQJV8WyfEvOiOP2g5xi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":557,"st_w_id":1,"st_quantity":78,"st_dist_01":"GmutqXh9H4Ztfq7YoGOZfDsE","st_dist_02":"HuBgJLgJZYWKPQ7gnEAlvRAV","st_dist_03":"6FdvYx8OO9yJOvuLN0ZG97Ae","st_dist_04":"0dZXDf7YyXV4y8GCYlG96NX9","st_dist_05":"Z7QjbL96bn7WR50tZ8DkO4YN","st_dist_06":"RVfX1a03ItKXmeyfQJ9SuNW9","st_dist_07":"Mp6IIapyx2VpAzxbchfmjeSc","st_dist_08":"Hi4uVidBEslEmh8YOJcua8Ij","st_dist_09":"kuKhqgzmPAYiK5EhGEJgv2mo","st_dist_10":"qQHQZm6WkUkMY0P2YSiEVwZC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"y2k86WXIUb1JVvnAWpOvgYCVDCatVV34k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":558,"st_w_id":1,"st_quantity":36,"st_dist_01":"nVJlpHtRz6LWoVSopU2n3Bmg","st_dist_02":"ykqiFj6agDjEZNsvyRjnbbeB","st_dist_03":"r4aOBKgQeDd8SqSIJvEBbekr","st_dist_04":"AGs7V7h1nMcGGCxsn6UzZCXv","st_dist_05":"AB0Lxl8hF6ICbF7GpRJxRQrz","st_dist_06":"3KdhuzmU4TO0ZEuFKrZayPvJ","st_dist_07":"yQDDQ5xbU73zslQd7EFLOMpW","st_dist_08":"yRhpFK7bAGNwfZpSmuKzjkRb","st_dist_09":"oPLoY5df8Z9dJVjbl4LpyVsG","st_dist_10":"htyI86IV92i19F8QPj1Mfr6K","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uUiE9DcnS9LyR6PIGJQRboA43kKkhWiduIM9XVs9M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":559,"st_w_id":1,"st_quantity":35,"st_dist_01":"u3vKUoeqcAbD5j7djEdlvY2l","st_dist_02":"At0Ni7YMF3XeRUaqjLPAZ8m7","st_dist_03":"3QpWai4BrfKgHNW9gZITZY4A","st_dist_04":"lqHsBn10K6p5UOfIqysofJlD","st_dist_05":"OSi6dLlRsCY8BU7wuYYs0Tbu","st_dist_06":"uM8DQ8rTbb0ksgmtwmrW4zAG","st_dist_07":"Ij2D9qkU7iUL3hYB6LjWYvAd","st_dist_08":"mnDMX6IQ0UtDd8CnLBvUr1bs","st_dist_09":"HJep8cvSWodNT7FihwX5fafQ","st_dist_10":"qdeGYQDxBUhgTudPMLp5XPf7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CdQfFwQ7i4GOWMZwbP7GvSEoeEY0ISz6f0B6ZHa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":560,"st_w_id":1,"st_quantity":65,"st_dist_01":"pYOv1QIRGTW0gvP9vxmR8UNs","st_dist_02":"jjsc5ZCjyNlQxwy7Pz0BNjh9","st_dist_03":"4nQoldm74lEPeJ7cvF2jrB5m","st_dist_04":"UEwXdddJaqfviOwx7YBuTt7e","st_dist_05":"2YXHkDwHNzjussyM3Ja7IzTO","st_dist_06":"6S7TGQTHH4xdFbpIkKBhYh7y","st_dist_07":"oPTgH2EH6m1IMSb6njwIMZ6i","st_dist_08":"7dmhXHDSIuqESyH6ihQDTN7c","st_dist_09":"UFHHm1zoqHJkw563Sb7wXMx2","st_dist_10":"ELMXVd0Mm5gKK3JXcHWMJiQm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"p3nRLEWCiGRUDWa9tteHDCxgzo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":561,"st_w_id":1,"st_quantity":20,"st_dist_01":"3OfVAXMliAsFcF4xhGHYJyyA","st_dist_02":"rPrqbfpDk2oAm2QeGbqnJTdf","st_dist_03":"gOQZWCYgfWxbxYCalzeC3Qpo","st_dist_04":"nIlXEOtYwvOl4HGr8OJTjFFn","st_dist_05":"rEbSIitvcUMxOnyDwhjkmMhw","st_dist_06":"CUpCS4MoXRNqFg8P0G08DqYO","st_dist_07":"qiEKHI5IZ0Biunjo6ngNzN7N","st_dist_08":"5lzA3zkh7a9t4qDPQJFcsOiC","st_dist_09":"TTBFntltInVgOhJBvhbyWVef","st_dist_10":"NEfJRmnXGcAh1gEcVSnciVM2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qO5C80ymdiB0ndRC9Sn31ctJgzZwuqfr0ccKAtHNXCB2U3pBI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":562,"st_w_id":1,"st_quantity":46,"st_dist_01":"TiF30f8l8ZChPtkmDFYaOXB1","st_dist_02":"lqFK71A9MQP8wMMzyOpZCyjm","st_dist_03":"1ulClHi86N6S5x2NyuAmL58P","st_dist_04":"jZm4MtX2PnaTasIvydDSpNPE","st_dist_05":"gkAh7LnlVRGoXs0EO7rXr4G5","st_dist_06":"0yB4wxe4gwq0GzBOyQLx8pm6","st_dist_07":"WjcNcJu2Hlf86ixvcySmAy4U","st_dist_08":"gWtVEG2Jhu6y0A6jqfGKLsXE","st_dist_09":"bYEdRREdKq7CEHwJYyhlbwW8","st_dist_10":"qBP0MRSSHsuEQyQIOSmvRDfH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xGAmpBaMOP5Q7a6ndKDfsgpAiolZAmd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":563,"st_w_id":1,"st_quantity":92,"st_dist_01":"ZkapYRUvOzDA7MU4Hy5PmKly","st_dist_02":"ieoEewEdfG2cL9Vk4Vqz5yJe","st_dist_03":"w1XwGhoN3eY7aZ1ihWGdrlOr","st_dist_04":"PV0I9VjV6s8bAWpk0miqJvLl","st_dist_05":"dbyUZyjxmqE7O8fMPVWZtSvg","st_dist_06":"bhfrWJ8nawkx1aBXANmH1qvE","st_dist_07":"JTjCeGfR3Pm2MSg5kOXJ2ibs","st_dist_08":"KSinnzLyMuYu4xvfpbvwouJ4","st_dist_09":"ATjkJuzRklhBVcHXovqlV2Xn","st_dist_10":"pp9KY4HJ18ZVd11AnVNnhfcr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cubZlvzVEYfxr5zGwMVNGEHRbqXexxlxSPCJ0pm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":564,"st_w_id":1,"st_quantity":43,"st_dist_01":"Hy2xYhdpRaphFYTCJ9FqcHio","st_dist_02":"zN5bPBfAZm0CAuKybqzky7AX","st_dist_03":"tZlmeF7Vfl5QER8DAgqki8ze","st_dist_04":"Lei2c0zctF28AvIF9C1BhsxB","st_dist_05":"9AFzPRkUmidYtweyaTuOKLIJ","st_dist_06":"Uj0nxRp9MU9itfdBu5Uq2N68","st_dist_07":"hUzmld6cxBAiyE7MmUj9sNkl","st_dist_08":"2rn2a1afcTtBfGQ30qplRF4z","st_dist_09":"dv2LcTRbat2Pptat0pG298go","st_dist_10":"3hRAhEw15L86JXUMZQtx97EX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2vATViXea7w4bNCu0YjvLHOA2VxZ63BH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":565,"st_w_id":1,"st_quantity":12,"st_dist_01":"EsLarMmNVBSrjbFMIWEmJZ9Z","st_dist_02":"FMW6EMA2Oy66FGAIguC1NBCU","st_dist_03":"BOyGn9ZGqcqRE6Quy9adHyIG","st_dist_04":"TlBshCn1xF9tBgoYTKB6rc9E","st_dist_05":"esM1cXEk3gkWJEYCXWzgZKvF","st_dist_06":"Q6BQsq0QKMm8zCWh5b3yPRNS","st_dist_07":"Ap0VJ2kz5mnqn7yv9YQIWq3l","st_dist_08":"8PxsFKhQhYctiPxziVX0Bqzw","st_dist_09":"e7sseARgMKl40ItOjXnLYs9D","st_dist_10":"YAUZosqCH9AOjkVeBqQ6xZbz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MWGhEUiB6j7GfHs2gXohNNr875YbXj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":566,"st_w_id":1,"st_quantity":44,"st_dist_01":"qAlvYGLwQEMpr9K8tasnnlaG","st_dist_02":"qDrHdm2GaOeiZBIx4HBJc5Qi","st_dist_03":"ORqAYgNeHJiC758CPIDDuK0i","st_dist_04":"qnlevsGg7bEObWTGRtaRrS9l","st_dist_05":"6MF2Xo218WbsG5uSkxp0HI2a","st_dist_06":"T2XK81PSk6x7EybuCfB2p2jf","st_dist_07":"S4N6YX1taiO6G7PNNYo1LiQK","st_dist_08":"iiWU3B6VMOfYIGEN94E5YDR1","st_dist_09":"rK1WOz8nlQ3vy1ptr1sV3z29","st_dist_10":"2tOJI1BOei9aN4YrWW0OCxPh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"o3ax5kludMAaY9wIdTaivmUCVk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":567,"st_w_id":1,"st_quantity":75,"st_dist_01":"chYE9SWpTaFTRMh5YGVm9sek","st_dist_02":"N3WPILjIaxoIRTHjno1TqvD9","st_dist_03":"3jYPutbD7XHFZUYUjl6DSFw9","st_dist_04":"1kOSexVvNIb0Iv4k9qIZlwtd","st_dist_05":"3S8SXdeN71jaCGL3gGmP7SCz","st_dist_06":"bfvFGrxMOjzqAvxXqqtsMgaD","st_dist_07":"WzcH4mQake7CkTJo0PanpZ7f","st_dist_08":"h7Az2aceTSsCwszKXHK1sVhg","st_dist_09":"eZOHgtbvMq5VcLjA3UyByXwe","st_dist_10":"xX0IlCdvgzXlDbjszKYUKZPC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NnsIWhEfnoyk858k2Xzje4wYatb9CeTZHSe15IiPIG03c"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":568,"st_w_id":1,"st_quantity":98,"st_dist_01":"Emjk33JX8xSznfHQlKyY2U1g","st_dist_02":"RCtUWxqUl9uQw5GRmEO5Sd6t","st_dist_03":"uPG7ZAwwCG1DDyKzLM9rHxv0","st_dist_04":"3fe8Mvhghyl9lIwn9BbxeHsN","st_dist_05":"GpNEb2H0P4uy2AAcYR3JCrMe","st_dist_06":"Ic8M0DV5b6EeYb2LPLJUgTBp","st_dist_07":"urVOoov0aIXQfG7NsWeW6MvX","st_dist_08":"WKXf4cGOdRBk4AzF5sZTp00i","st_dist_09":"N9zicrBS7GhBqylPk745SLUz","st_dist_10":"cfqEK92tVPkJanq5dr6TmhI3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0DURd82iW5ZvdrhCaXMc09qHMfZqxkY86"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":569,"st_w_id":1,"st_quantity":24,"st_dist_01":"K97O7dxZapJAh9JDGf1TrwRB","st_dist_02":"OBPsPdWMLmUVcG4PBCjSABva","st_dist_03":"cIjTiWYSrRudtvWbsfG9rNGk","st_dist_04":"712hdaHPGcRtqak5XBBWKTpE","st_dist_05":"7HA5u3H1JEQjVbEFYiEEB0YO","st_dist_06":"30sqtvAkxq0n9jEocQSy55ET","st_dist_07":"Cu8qdXD9jg5eO3R2wkCuueAG","st_dist_08":"bi2CbHCfhHqtwW0QIgN5eYdd","st_dist_09":"V5V25bUz3mV1xWPQCQ7bFyEJ","st_dist_10":"PLyd8BGewpJaOhsB2QMXFa7m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2Rnbl2j09wtDDGCeCYyKz3rkPHaB4IbiJ09C3oKUFKFqh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":570,"st_w_id":1,"st_quantity":68,"st_dist_01":"LxSfzQksqPgk9oTIvsp64XwI","st_dist_02":"faiWsGRCkWOrhpOrQfM034ZG","st_dist_03":"SwX4iKoeh3iGVJgmuqeKQDUL","st_dist_04":"Dfu58HEHww5Vdb4ZOEI1em6i","st_dist_05":"xLX7kinZeJKNZhfkYHQkmQbc","st_dist_06":"vRmfNw5Toiq46WhKSVskOKyA","st_dist_07":"hSlM0b7ZyFWaHRZJqAJBKRSk","st_dist_08":"8PCLr2Rg8oVgHEHUMt6tmol7","st_dist_09":"X10ss6x71VnPmO5EAMupIDEg","st_dist_10":"rYN04Y6I30xFxrvjD31eZqwT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O8adH9aVPpHVu8RK3KEAbyt4ST"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":571,"st_w_id":1,"st_quantity":74,"st_dist_01":"xBRSRJbimSIxoBF4xHTGMUTa","st_dist_02":"DPQgwu3ZLWvQZYtEq6ITvmf5","st_dist_03":"rciG50AZQheFGAXHujhNWu58","st_dist_04":"llPxpDWq2fi3XkAf0DA1LZ85","st_dist_05":"wLB3h5XWISyErtqXh9k9Qhu5","st_dist_06":"m8my1vU7uC9P5AowSNUMWiNV","st_dist_07":"ksl9WDvFmy77LQDCmQxhs8N9","st_dist_08":"8RTwgZqGDZIo3K2ZzrheVU8l","st_dist_09":"1S1ItaoxgG4r0L7oJZVEJP01","st_dist_10":"C2beHbYJVOEvbQU5s8ZJhrty","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FjQlg0AbQmH4Rx42AUbFGeCJMW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":572,"st_w_id":1,"st_quantity":82,"st_dist_01":"B5iDXBstQK7VXlBhvPZdjjYn","st_dist_02":"WE4Od2eJkZEcfzKWvTa1QHzO","st_dist_03":"37TkcRn0bHMna5AzP56GvIiX","st_dist_04":"ZT7do8O3QXI26yPxcYqpGSsV","st_dist_05":"74pZSwaXJsrFAL3VL75uLmkA","st_dist_06":"5L3xb5lXKtB2Rmw4LD2h1hXs","st_dist_07":"R10SMJxINn1M9W3NGeSktj2u","st_dist_08":"7unmgAWwwk78bO83RLArQLqu","st_dist_09":"25SheuA3iJZA3wa7KNVAG1T0","st_dist_10":"oZdiD25VtGnpVoQ8rgRhsaUP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AxHVEa4rSuTVeyFKBp8xkmEcmebUBKL1XlZR0oUeB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":573,"st_w_id":1,"st_quantity":73,"st_dist_01":"oI45pDu2KbyICAkpxIfAee7G","st_dist_02":"HFw0RSPmCxd4yu9IkWo08DD5","st_dist_03":"7rjHbqJTiiunwsSxlfvXnBZ5","st_dist_04":"Rn1zZTBwJo6THwnZQOqeo5ES","st_dist_05":"PX2xwHR7lJhmnZKDdvuY5zIO","st_dist_06":"rrVFkFAdX4L3S4FzI9LA2EQO","st_dist_07":"PmcajQkJWKZCO4QALXahzKxp","st_dist_08":"NeQY0RqCfWu5SbNjIB36hmvH","st_dist_09":"BO2DKEIbvYjgoSiJmq9N46zp","st_dist_10":"3cpfLilZ2KEs542jHf3R6eCU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gS4ggYLGKJEN8A26X8lmU5gRosCmIh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":574,"st_w_id":1,"st_quantity":12,"st_dist_01":"JOu6y7lzoXOyDv8YJHh525lI","st_dist_02":"LZZqYzTPAkcM7em8TVBDmRNr","st_dist_03":"deVE4tuovJAnh2h0jRohM2RF","st_dist_04":"FVK64dXmHONYTVIJ5Kw3OTKv","st_dist_05":"wzM9IoA5gE2UhOFe8aGEfhTH","st_dist_06":"iUeyMSjnPdfZsytuN81YumtV","st_dist_07":"WZfXWJl8fxH7k0fZ8sLOt8gG","st_dist_08":"HVcwgOjeqygKGCeBJhtp9I6v","st_dist_09":"e9z7rynVrdQbdT1263EJcwGm","st_dist_10":"UJO4rFGoKyQhzzzLSZyksDuP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XAdawUrRXQmMGnbEU07D9edxM3ba2s5knExB1M9gGJTxNARlL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":575,"st_w_id":1,"st_quantity":67,"st_dist_01":"pSDbvpKPWo9NRbUH4z5KxG6D","st_dist_02":"P8dsT1Snl2sq4tpgwjEoh7OJ","st_dist_03":"iua6qC9IPXSuJLACw4ckrqS9","st_dist_04":"niI1YUZpW8n4URswtCaxgb7W","st_dist_05":"yja0fRId77FMH8yTczxt0uvm","st_dist_06":"ha8LgaVPrlz6VSm7B2jzciui","st_dist_07":"Nleq5Ehs1KpnlUPVOtD3c2C3","st_dist_08":"MpD5SUz2KfUoZOoZL1Ydz5iu","st_dist_09":"Mr1Fek3UblqHBLsCrxwNBhTw","st_dist_10":"Mif9KUzIZC4ppZ2kyqiN004L","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wjh5nDiGbZtMKfQBWc81CS6UWm7tnGrXXJZb2QLQi33sWEOV9j"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":576,"st_w_id":1,"st_quantity":45,"st_dist_01":"uBpwVTm2CIODTCv6WxkY8eFi","st_dist_02":"mZT4wSLuLqtLPj43KNPK3laU","st_dist_03":"It0vSWB1ojgHCrdAdW1lPc1K","st_dist_04":"oFCyWjMNM6HNaK0fRWEseXs4","st_dist_05":"2MLOavwNcNdkt69n0D9YblYu","st_dist_06":"0Lhm3IiF4MmjJt8yZG0US3sD","st_dist_07":"y4exPZmU12Ew4lK4pZm487WH","st_dist_08":"pQ3H0JPOJYKhXcfvGXygTRA0","st_dist_09":"vaT8Jk2XvV2baUQkpJWUPRRI","st_dist_10":"4CQVtFX5EtsGEmStA5F2JCnV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fGHNWUFIbFtV2YTawJqU5X1b9dn6gBGAf9RtYib9V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":577,"st_w_id":1,"st_quantity":81,"st_dist_01":"3wpTHMGnvRK0sYSWR1qHoxKP","st_dist_02":"U8PL5RHHIRSAZFDG6JKCQLm9","st_dist_03":"RxaPZRjb19eh2PRCD2kE5NQd","st_dist_04":"hXcY5NkooCzYNupn0T1i0t4o","st_dist_05":"McletJ59W6nYsqYaXsBP09Ox","st_dist_06":"sMSW2XbsrYkvNchv92gPbgA2","st_dist_07":"clcrfCFxgm0OA7CgP4TO2vvs","st_dist_08":"wTcWRw0CWZKUjfUP27UqbI4b","st_dist_09":"RF8JwZEttKCldwdkqav92nc4","st_dist_10":"IEp8PMrozsL8WA2t2Q4QKoOP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pvl4iAwSHsB797lswefucp8mPccutFlmbgHv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":578,"st_w_id":1,"st_quantity":42,"st_dist_01":"uxE4tvTYwPjRNt5cE7wUZ0zM","st_dist_02":"u7aOyso4fJVhSTzOf2NDpoyS","st_dist_03":"K2L1XdS2xncr2lnBWCjj8w6F","st_dist_04":"WL4fSQHf6KMYELak7u74I06l","st_dist_05":"XHZgfh61PvPoloCQuJt1ESQJ","st_dist_06":"LVNFtGwTPv74KxxRt6hocGe9","st_dist_07":"LDOUt4O98r7XW92ARbgtJFpU","st_dist_08":"0CwG8AxUl2AxEQxIKpE6XbCy","st_dist_09":"EuadQv3Dm8MrioU5Fos8Lcd1","st_dist_10":"Am7noFpWtR63xp0FxSEOsyGB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YtexRjErONoSajMgG2OLIh5y7sjAmmkUI5KwAJRCAy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":579,"st_w_id":1,"st_quantity":98,"st_dist_01":"DyvO3an9nD7NzZmyNjcVITCD","st_dist_02":"msgPHwJxCDNmwmGEhz5Rbf3Y","st_dist_03":"pJoGpziD6fzGBE7EcyCfWcxo","st_dist_04":"DxKRwxRfopFz3VbTuwlyGxSh","st_dist_05":"NiXzmOy3RQ62nvMbqjPogFKw","st_dist_06":"eIZZaVtZXFuNdXcswkQpx9dK","st_dist_07":"1g3sIMZsqm5xysOB3rpcmKL8","st_dist_08":"GRysVBBfj41H4OPfumonIdGX","st_dist_09":"A8OrwEqb2KlwW3xVpJ3WYOmN","st_dist_10":"y6sPHyF7gVXkjA2XSFXT3VZG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6VgUKoriginalHm56gbDRFt8YejHirjZcIZImhOeZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":580,"st_w_id":1,"st_quantity":36,"st_dist_01":"YHGIfqgsBLPjg7OUY07zkctL","st_dist_02":"3ZmgdbJ7uzd6bUwkkDb1KMUT","st_dist_03":"3u6kjQtwZcSw2jC5Hn8l9tZy","st_dist_04":"PUpfg8H7Uj7bph2ZdWxMw4z3","st_dist_05":"fc8kufZoFxXSDDcKPofYGNF3","st_dist_06":"MarVSJddQJHUNFQzQFUMAhv9","st_dist_07":"2xKCx643W6MK784wHMi9HzAY","st_dist_08":"PwD06qxTa3vJNly3RJP7sbUr","st_dist_09":"3itw3s5Cz8wHvmar3IRDnVoj","st_dist_10":"DqZ1Vegl2KQYfDR4fja19TsE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"frOK2dDKjUrc8aUeSFCQcPdLeNOd7uwymhOM10kCKzK0mcHdo6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":581,"st_w_id":1,"st_quantity":20,"st_dist_01":"7RqZ4i0qKfx7Id5kEqDIpNg6","st_dist_02":"hyAJqW7HeGgx5286EcMr4LUv","st_dist_03":"JvqWS1iXrWBP4DCbohT7nseK","st_dist_04":"RaDOOQGWE3BVgTGe2kMM5B3k","st_dist_05":"MtKgqOD5aiHXdtO4sZ1z0ddJ","st_dist_06":"opqOqdfwfFjb3DS2KT9gEMeH","st_dist_07":"GYbwFvuzNv6mAg8cZpoQPFzB","st_dist_08":"NyRzxSxbamZ2qbnrCMtbNL7l","st_dist_09":"ItjOXFpuiwUSsAfwMLGUs9Mu","st_dist_10":"ySnlTNYY5mrwHXNnMrKyBjEv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FEaYoriginalVyF1jO8M6VTtofvx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":582,"st_w_id":1,"st_quantity":10,"st_dist_01":"iGOLdescM0Q45uQKmABO69AI","st_dist_02":"l5xUCwBA3UKBG8L9nDPwHDKS","st_dist_03":"w9wGljGr4uckVhN3JT24kyVG","st_dist_04":"bogTZk1m5irDjVEhWsgms6l7","st_dist_05":"chYLsOFYhDF3itkGiMAtr8E0","st_dist_06":"XoBoM6dDIS5Ec4aRKLt9ePS8","st_dist_07":"x16vEIxZ8x1rPPv0UyFtUi4M","st_dist_08":"GKKHYq1qvhUaKaD6PxciO3G3","st_dist_09":"mHrDtn3wEmL30TlArLjE1FXv","st_dist_10":"WcF1VDGK54rKgeCcVmEcK493","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"71QoEXWINW6bdIPKptKP3ypGvUcmOSA51SIxJCr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":583,"st_w_id":1,"st_quantity":70,"st_dist_01":"N8CY7rFTbeSledyeYpz8tFKb","st_dist_02":"5Xu4PBqfBRnJ3Q4xhDqCaMUH","st_dist_03":"JEHQUkTzzIjxJyr8VNuIv0wN","st_dist_04":"04zf1eGKVgQxElkirmIWCWfU","st_dist_05":"VERx4tTLFjmVo0BAMbVYTgOt","st_dist_06":"4IzMQMKPI6coR3Iwui475Tpy","st_dist_07":"9Ww7QOCIuPH1eiIb9WDfPQQD","st_dist_08":"4Uer5hmpNiPBCPLhxu4ILyDw","st_dist_09":"x71SpaVckwqWUbYuacUZuJls","st_dist_10":"D0vljCIEkfWdFyOh4t8n226T","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jsaAP1XQ6zZMOYiZBZqBKHsZd4cQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":584,"st_w_id":1,"st_quantity":19,"st_dist_01":"ksNAKi1ahioq1yKDoRL2xHkX","st_dist_02":"VGaF5ANvMn7wnQnPQuZA4TCQ","st_dist_03":"R66mUj0KcpvPvKJ5tbEamuhz","st_dist_04":"z9RjCs3XEl5dWE0JUFIVpwHf","st_dist_05":"KJ93v7iPwt0gkpEutH6h6CUO","st_dist_06":"W0fZldSaxI1BZcTZ7SGT8bUc","st_dist_07":"0jVQa246mHs4xzJ3AnOJUXGK","st_dist_08":"S446tgaS3XN5XHVe1I45x15i","st_dist_09":"i3ZV0M8TxlJDwEyb4U3snIZN","st_dist_10":"uaEd1VI75VlaxefIbJB0Szbm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bxGk50gxAq40v2QhyUNNimqyClkv5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":585,"st_w_id":1,"st_quantity":47,"st_dist_01":"Nu98tVba1gwNsuaGhliEmYqx","st_dist_02":"tyQKWLQ2VbTltYmFYWqj5iMD","st_dist_03":"v0UqKiDip870n6YVyLd26Oph","st_dist_04":"GI3IBdlCaJxZoqL0UGr5HTS6","st_dist_05":"AACtDWEG2e7rd6gnNyr67m1k","st_dist_06":"aiughbnsnJpTt9cjIJmYBPgX","st_dist_07":"lWNkse35TtQEIQagZx77kMpu","st_dist_08":"Ok0fhD9q50XQDCzPsMMRs3yD","st_dist_09":"tRCC8l7uLWiw3g280hze3ZJr","st_dist_10":"r2NUkizpU052OdFBvJ9vR5H5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eSdXLUg48ElQrqFX6EApAGUmWRPfi8GNPICD4JVG36"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":586,"st_w_id":1,"st_quantity":30,"st_dist_01":"zDabEaBcsEI804yLTkdEOcug","st_dist_02":"3dlQ6BFFNkRA61jKCeJ7Asu8","st_dist_03":"6ggKcfw5Kgocshqx012qtjLw","st_dist_04":"4CAnfQ0ua47ELPyuI6E3MoQk","st_dist_05":"fWP9d6OmONp8YGT2ZWkRXhnm","st_dist_06":"XfyOgqHtfkBJq7hV9F1eZodd","st_dist_07":"1Ehj8o0JiElgv7H7ZRczaqJf","st_dist_08":"EfvxTZjcTHxm2L4SWGjfVK9H","st_dist_09":"ST6aayDTqCj4cmUI1E53OY4d","st_dist_10":"KXhGWHK4zHzXiChdVit7UORs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jj3kja8xFyAtpw6D1I5BoXVBVWDw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":587,"st_w_id":1,"st_quantity":82,"st_dist_01":"NauwZ5pflFE0hBTTknftg0MR","st_dist_02":"lrft10P4zWQO744UPQypT509","st_dist_03":"GOJwvI33BAHqBidTgIb2tPBr","st_dist_04":"hhGzP5YnNM5qFlNqqElnhJL5","st_dist_05":"u0kYqVQAlTgbeSscowL7fjcg","st_dist_06":"7N6YuMpznnvPfOgRH0II1wdi","st_dist_07":"xOVcHwbMWhtdgBVGqQ0nPGuE","st_dist_08":"ejI2WG3z719klfLeDcoEeL1U","st_dist_09":"oZvOEe0mHeCFB0UmYXgJUT8g","st_dist_10":"SlIG9sup51Md4oobgVT5lYw5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lHsGZRm0zhXKU7iT0m52VN3wUUk0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":588,"st_w_id":1,"st_quantity":52,"st_dist_01":"bYt2c6Mb23tKGxpaQLERbX64","st_dist_02":"zSa3ijw4HFVZ7AIuoh8YF27U","st_dist_03":"6oU4fetx4sLyPNGqwI6UGhEX","st_dist_04":"wxm3ZCu8Vm8fDC0wQ1TpGeeL","st_dist_05":"xrqQ00VSxqHnEnr4GesSY36d","st_dist_06":"WdWBSHGrY81mjyRILy4wYeJV","st_dist_07":"pLGS0Howpp5AizdAYxqhY7yV","st_dist_08":"idvFbAyC69bET7ldFdlynIkR","st_dist_09":"m25r2HUMJ00lxVhouxOFxQtT","st_dist_10":"DHzncNIL4ATiV4PRFLTf1eLp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3mNFygZgGExTQpAJhbyDygEZpg4z39p6Mw1c1IK5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":589,"st_w_id":1,"st_quantity":56,"st_dist_01":"qgagRHpteaPCwejMHjg8vHPw","st_dist_02":"7QmpRZI0VgvjAxhtvgCNKB0w","st_dist_03":"kV0a0QWKEPr2wIx0yM3n3adJ","st_dist_04":"rQ2PfLqeVzc8lEHa0nvf5QJK","st_dist_05":"CFvRVsLlS96o9UCDmIrLFvLr","st_dist_06":"EisvIZqBslvqhjFvN3Vaytkq","st_dist_07":"0kUpw2tna7zuIpHmUt46npS3","st_dist_08":"TBv9ur1zTml5WhVsZzB2sGkg","st_dist_09":"2MOPvo9waV8B09auFURSlYYN","st_dist_10":"kSj94fkNCveGdqk4ugXeuhXE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XmO0kt8tFJ3mS8xCNYR7LUceBj65JGdaY18IIr7M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":590,"st_w_id":1,"st_quantity":24,"st_dist_01":"O3yZieDf6oUYSN09WVnjMb1Z","st_dist_02":"8qPBBDelCt6YjWzXGEsW9UV7","st_dist_03":"S2hlnQREW8fDaO5QdUb1X826","st_dist_04":"dxonzxgzrmstjaPcTg8HbIth","st_dist_05":"H9eTGEraODioqpMH6AA5RKrj","st_dist_06":"rpPyhbT7Faur8cYMTKkeeIHf","st_dist_07":"zzw6aYxcEOOfa97cEsEpPIAq","st_dist_08":"Hmg0wLtolEfCvvYXtVGS6TEH","st_dist_09":"ZC4xHAJUCLJgx9ysdLffQoh8","st_dist_10":"pOpwead5pkiPX5PLjst0OD3Z","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9Vn4GEyNDvGMRBURSjdMQq6IItHd5ajBvcHCho4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":591,"st_w_id":1,"st_quantity":45,"st_dist_01":"5lr0Mx1iIPCHgdJM6LD3lSRN","st_dist_02":"Jna0tlnDjF13KmRDlx3hwXSo","st_dist_03":"2dZE9lInArK0ftKEWLstExaa","st_dist_04":"I66Mfr4Rw2lyUUIMO83YfW5C","st_dist_05":"OjeaSNumUS4bMYJI4sdCO2oY","st_dist_06":"ZJkCdxwne9U0yW1A3Pybv1kz","st_dist_07":"xUbDMkSqZFx1OudaednBbPUN","st_dist_08":"V0H76hXjIxqk2AcOcURpHBTP","st_dist_09":"NRNokVWiFiTA5gTrtv9adkcI","st_dist_10":"hLD1nlfiIGcSD4yC8CxMPUx9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OVTlKRLxUmzYRfx3bYV7GlIoecuH1E"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":592,"st_w_id":1,"st_quantity":22,"st_dist_01":"N2exO60ytJzWhERhRvOlwsHf","st_dist_02":"jjXE8x6M0dJkTAQ499534fm7","st_dist_03":"fKhGKCSWvJkY00Z0wY8aRJVO","st_dist_04":"NSj0LCwa4eK2M1XIbhwxhQIu","st_dist_05":"CYykt5ownugrL7r34VlLh7cf","st_dist_06":"GcCKcx3MiaaYlfsZEkt2BLvg","st_dist_07":"gDDonyek7QW2QN2aP86oQNcj","st_dist_08":"E8Qyw79jNJ7hv90XaZB6VDvl","st_dist_09":"SlkW8Kx2GVp2Q7nqkSon9pr9","st_dist_10":"KlRM6pPEyCk1IXZvMS1UQLwJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dA95Gns47sAWuSveDXVeD94BxSnCdXa7MPl1tcV14kC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":593,"st_w_id":1,"st_quantity":16,"st_dist_01":"RZfH6Rm5GpsB1eFMCxsfvgTx","st_dist_02":"2yy1b5m0tVyDtgaqVkc4yr4S","st_dist_03":"HWrsCaGbnxLREoXKZ61bN9es","st_dist_04":"ZYXmJGuPDaEFnc3rORavV0Va","st_dist_05":"3c9askVNtOQQSGDz4gfaZ2bN","st_dist_06":"Zc0azc8keUG1BiCaTBpz6FGw","st_dist_07":"NZU7PJG2OHKOvUc5HeVi6EhF","st_dist_08":"IgUBfgoZRtGZkR8A9llh2v8d","st_dist_09":"Mrl30NcF3VAEleiIlZqtXwJc","st_dist_10":"SkDpnq8i6rQ2QfuvPZjiU4HI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"z12cGzdlbfwGqquZOzji7RFQxocH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":594,"st_w_id":1,"st_quantity":73,"st_dist_01":"Qkz1vxFwXkiz0HGRl99GMD1E","st_dist_02":"D3PZMsxxZUANgRWcX4W1Vf9j","st_dist_03":"bQFhPR2AB8VSbfdnArUb4naR","st_dist_04":"k0R9b0yOW5D3Q1M6g47LA5M4","st_dist_05":"zSc3snElutxsx9QjoPZ6Iroy","st_dist_06":"VjIMSOo4OMsInXPZolrVLUak","st_dist_07":"UphOR1BXmjxLxVMIVrpIJQLp","st_dist_08":"9NEYbIwrNguaGVIe4BaY8umt","st_dist_09":"gPSSHny3yt8aWhEqAObkJEyC","st_dist_10":"gcbNRZK6MrKBj72kpSHIRLvW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xYnhY9ZuACRnlh9xAq4yly4Uhc4xgXp7hDLRhsgb8p"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":595,"st_w_id":1,"st_quantity":39,"st_dist_01":"DACmg0snAWBlLOLYM1exC5pM","st_dist_02":"Gn57UHnNhFKWzW4l5M25AlX1","st_dist_03":"FHA5ZIYsGVmGg5MPxM0vxISu","st_dist_04":"tlk1FoVSVFMaluDgyUMzi9Pc","st_dist_05":"QDQirRWyi0woMNhtzUuOG3fp","st_dist_06":"wG8yYAUu0ViCPgYxL0gaSwY6","st_dist_07":"zKXrUQ0tfjsgncbZOKNEgUP4","st_dist_08":"qatamaCzufABTJpAkcRYuYHe","st_dist_09":"otI57LDVCVioNb1UdmDtH0TB","st_dist_10":"gYiZ0bcs3PnMmOCBWGyM4b5B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lRa2oJQeCKiLzToVWZPXRMqOb3JBP7VmE3V2A04"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":596,"st_w_id":1,"st_quantity":81,"st_dist_01":"S7WQkZNCRJ8YcZe7qh5wenim","st_dist_02":"HGC4F4lBm7BAB9QUFPh4Gf4K","st_dist_03":"vL0FzHrB870uQ09lf0vLniNG","st_dist_04":"eFcAAvTu1fMK5p7iAjrRh9sk","st_dist_05":"HHgLTfm8yFr0Qj1evzCVbqhI","st_dist_06":"7AdcC0rWEfo71FQlsZ6hJJEL","st_dist_07":"R5JItUYVZfVMICV4b9LP5EAf","st_dist_08":"3vh9UC9zj8Z3Td2VFovdSfRZ","st_dist_09":"NSZ6hPwGip61q9TIHMQ40RvF","st_dist_10":"HnkI0CQccB93HgM0TiyWjRQc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NLGC3PqVKZIeMe7XHz5SVZ5uiXlYKkjmXGvCwUgxzlS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":597,"st_w_id":1,"st_quantity":76,"st_dist_01":"Jk2XpUFydUaiCJ3D9K6xwgez","st_dist_02":"wxFKFbNKWdMlHbjTVsRH97M9","st_dist_03":"6435neYbwhV7xtexT0mFQqg4","st_dist_04":"7mjrxrqeiRfE6I7RhEZUGMuW","st_dist_05":"7eX3v7m1PMulmSCfsStJJe9S","st_dist_06":"9T9CIxjvk1R9IDOeBI4uaWrL","st_dist_07":"EvoP9BgLkJMcrHEyk1VaKFS2","st_dist_08":"UCsWgPAW2pGTjzmJVXw0haDt","st_dist_09":"QrhFKNsUM3OVd124NEGQc0F8","st_dist_10":"V6xGQGuJM606Ss6Dwqa5IMJR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"T4E1YoRirKKMJRERStDuhosJu4ACYPv7QFC9ikbMt2K"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":598,"st_w_id":1,"st_quantity":94,"st_dist_01":"Vvpy0kLPKrm9bg5tJ4SxEKD5","st_dist_02":"X0Z557EbJcEHm5FukF8vge52","st_dist_03":"0yXcYdtiALTCVNIZ1z11UnyT","st_dist_04":"9Sa6iMmX12GfFgPtqkJpXbaf","st_dist_05":"RgwqMTSpd0NgEEC3NfzB3RZc","st_dist_06":"uSiSxyRH1tbYno6eQhe2dp09","st_dist_07":"1D6luTCXsXLhyScjpg7Ky58z","st_dist_08":"6KKvzDCHPOwElAYeiSD6r49j","st_dist_09":"19cn61v7Nul5apGtz2qXRxxF","st_dist_10":"EDMRLYBBWaVujwpOvxvpy6ed","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZnS1YHbw8mu5Kdisg8fk2SlIsfVw2WRfT2LuLW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":599,"st_w_id":1,"st_quantity":49,"st_dist_01":"bBW7G2ms0URXxX07StA0oGCj","st_dist_02":"ZnQ2arCJIOdxpR69EwzihKY4","st_dist_03":"XLEebv0bBjwZm5FLMGhN4mL6","st_dist_04":"rcuM022t42LTx9I3FXVg60n6","st_dist_05":"sLSkCJXuddZdzjNAopnkbMqF","st_dist_06":"snpM5bMs7nT34nR7kIXzOiOw","st_dist_07":"brY3oxPIWFrHMBSDJlruZbgH","st_dist_08":"Abxu2QT4Cm85JaysZHRWotla","st_dist_09":"ql4rbMtVP5ybPphp4LBmxEyj","st_dist_10":"ixbDESLc0ODfGOMulb2WyId0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jvaD7VClXNNUPHGQlGhFAzUKgHIeHEPwdkiOZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":600,"st_w_id":1,"st_quantity":13,"st_dist_01":"gQ2IsvvjEqrIe8FZlHrT3xOx","st_dist_02":"Z8BxpEWY3djhgwDpvzhHJOSQ","st_dist_03":"DuejZxWwjs36NjKMqdceNAr1","st_dist_04":"vn3WawBG6B03qzjKQtr4eEGW","st_dist_05":"MZDwjCw92Dfp4fz43GDOclCl","st_dist_06":"02N14f8sJOw7oLowniZOXdG0","st_dist_07":"lvz5rPm7mY1CsczekzEom525","st_dist_08":"gGzoog4BTK1uIcQLhgMOzxaU","st_dist_09":"ANYteROUXQWlAiiv6EgXyxmy","st_dist_10":"v6KKxqJEoSrvrsgqggaPCoS6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DmCPvysCV0Uy2R6Nn17teAHlIqKhm8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":601,"st_w_id":1,"st_quantity":23,"st_dist_01":"LE21xZXUBczfwpoX8e3vt8nQ","st_dist_02":"qmGGHgN0qJVNXSgTjm6cu81k","st_dist_03":"NiI9X8ghAnwS6b9iaVAgHOw2","st_dist_04":"WL535Cj3CKSUv4ibwijweruU","st_dist_05":"S6DxTeCisCG75UhGWuhJdAHc","st_dist_06":"WrTUkejPu4wxAmPJ4v1mdVXP","st_dist_07":"UPaqGmJDtldLi7QYJtiYPGzp","st_dist_08":"rTSq25vD2qCL8vDG1n525gFV","st_dist_09":"2GTUCHaUuA9f5HLbIy8LOfro","st_dist_10":"U2OaFjg2AL9DmunjVSs9HYB5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LxLmrgEARRwDjGAYtRoLhJKLEXc6pzGe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":602,"st_w_id":1,"st_quantity":42,"st_dist_01":"fUnaEqfu93PeiL8TI2xXuWKQ","st_dist_02":"eYvwcBMq3XS1ou43Eoge2YWQ","st_dist_03":"Z4PY02QFQ8YzGDy5EqR7CKHJ","st_dist_04":"EzebfzwOMlYKJvIjYhw2gUol","st_dist_05":"aj8PZ12iTO0DwDDxX36BAAhD","st_dist_06":"vLJDHWcdrTGRlOwCStlM71x3","st_dist_07":"COXxeo95aeYqERqBf5WqniCW","st_dist_08":"IVY9gnvTrhpe3OiOCj7xra2q","st_dist_09":"Ye9vKAU21Cci5Sd0Ziact0fm","st_dist_10":"pzSNDaqXqebRh2c7M0XGv8Qi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v1WSDGCoriginallKVssiuhI5Gz3y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":603,"st_w_id":1,"st_quantity":26,"st_dist_01":"ri4uYsZeMiCWlosuaA7yhNf3","st_dist_02":"hOor7qOtr6lPJ9uUAAL2eOXB","st_dist_03":"5dIr8Cjm52yXY3u3oFdXfdk6","st_dist_04":"ZsdcaS267QzbZzHreUDw5Kjh","st_dist_05":"NA92YYMmJ34djc2RpV1BVRP9","st_dist_06":"mZhDn80Y2uLlHE3Ov8z1FMUP","st_dist_07":"nK9R19QeUWKE3flmNjJarpRq","st_dist_08":"W1kWMMFpNYY6kqGVn80ofDSJ","st_dist_09":"Ir4wh13om2PVZjIqI7NSut98","st_dist_10":"5uevjqsVlpsr0xVTUWJJjFjN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JrQeM5D5neSATOlbDudHmliHLQvsGm3z35i1sQ1xaAkzojm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":604,"st_w_id":1,"st_quantity":65,"st_dist_01":"D2yNEwmT4kChdXXORNDVd2o3","st_dist_02":"as7J5HGubtyJ3q0o3DNMPuF4","st_dist_03":"v5ii26iGBV1OjjGL5o6cNepu","st_dist_04":"5JAok6gE8wHMjFhJ0rFVI6G0","st_dist_05":"MoyMfyiBTcptJdbLT2Qoaorm","st_dist_06":"5wqwDW02kzkEcPAY1LTcE1ER","st_dist_07":"0sjacaEOjcHxcsbbIQbPeyjM","st_dist_08":"WeX75G5w9k1IsZ1IVzZkI5La","st_dist_09":"ds7NpuCKUH1LxeVqDVljGDKY","st_dist_10":"UkaLtKfreBJnm6E6V6XK3iHE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ul7SXU1md6RaLxiLYNQ88QD4KnNPVj87s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":605,"st_w_id":1,"st_quantity":28,"st_dist_01":"jb6mW2NgLQpnY55pNUhCXYbB","st_dist_02":"r8kP7dXGEW3PopgV42JrEsIr","st_dist_03":"0ni5Hi56UU7rjMd5jJxfmxMs","st_dist_04":"1UqQv2YEthdHepO1eRem4b6A","st_dist_05":"ke5sxQ3js6qEgBfISrTODBf7","st_dist_06":"5MSIc3tCEfC9c6Wre78WyhW4","st_dist_07":"PQ0tlhCaQ6qDH3MGeTqlCDRG","st_dist_08":"A34pA2A9IBCk3cGsge0QB3uJ","st_dist_09":"mqviF7OKkjVFZVTkMJ3HDkR3","st_dist_10":"JLlVnlv5I3ovOAkPkc21cMHw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lJobXwpCwIhAzwBbdiLlX96f2K7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":606,"st_w_id":1,"st_quantity":56,"st_dist_01":"PxmRIWb05srTTBvsQQ6OjOhy","st_dist_02":"QwE35qK4OeCbbP03xbG9GuDa","st_dist_03":"pbkGzCzAw8e7h1xwDJUkxnMh","st_dist_04":"7XoISLIO00H2f5KajMruK3T7","st_dist_05":"2kZgsMI4HSOrzjvIAgz1QIMs","st_dist_06":"ZwvyKEzNd9lBtV25SBvURsTF","st_dist_07":"arpclICPeBgATw13hd4tMUkr","st_dist_08":"rj2IYzsrCHCoeK2bRYxFQDfP","st_dist_09":"OgRa2eixtD2ZA1o8eMg10Ez2","st_dist_10":"2jq9RFzOsRO9RLnmZcZYLoPQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"breh6elAgZoriginalGTd13DK8eWQ3h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":607,"st_w_id":1,"st_quantity":70,"st_dist_01":"wbwNFnDevhZd4Uo0GtE5Nu42","st_dist_02":"YcLdk8dCzEwOZv2IjqikwEHg","st_dist_03":"I6OEF0SpTab0anXbHnMSakaO","st_dist_04":"YBmNwiO4PQ5z7kqYecvz1UBN","st_dist_05":"0BuH6qorDmCHa1bKgfBXcVmE","st_dist_06":"nxOjQKaU5nVd6mEIeBGKIAti","st_dist_07":"xNfVuplzfKWIRkwFfEOnaE3L","st_dist_08":"jsTruxDt8KHanxwLQeCATd4k","st_dist_09":"53xjAH1btucPBSSu5CHDabPs","st_dist_10":"FRDvdrYywu2YjpCFNRpy4DGb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PhslkYsP1Ub4KabF1fWdDh8ynHLLZhg0tlXd06goqs4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":608,"st_w_id":1,"st_quantity":84,"st_dist_01":"PhjnrJlEWg9J8jsDCEZ8VGo1","st_dist_02":"BxewTB71suXTKNQztcmLliZ1","st_dist_03":"yXqhJENIA6b9bb2uNRFtaVYH","st_dist_04":"IvHMcjZA8AnaWX81fQHG9vm3","st_dist_05":"cQqvSfmO1Pmq14seteyYRF9U","st_dist_06":"cjtd70TiHSM6CDGdaIj1RjaF","st_dist_07":"XQjbanSbMMTE8oyAJqOaMo7E","st_dist_08":"nNgcmy4Ck0tpiWdtT5dbZVMv","st_dist_09":"dIu6bkU0GfbkYc5vzlukgaAe","st_dist_10":"G91MyvzGtQtn3aKqGH7PQYbY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"z8DWoQ6IovxkMBrwDLEcfmb2jV1x1dFv5X8n3LzrEx8T5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":609,"st_w_id":1,"st_quantity":21,"st_dist_01":"s8qPlNaLBxr9HnIq3GR8hgpo","st_dist_02":"Pbc2szdgKtMXUQ1QEYgjWZRI","st_dist_03":"Mm2S1qsUSzqLDLjKnz7H3SxF","st_dist_04":"Qipx0jjK5Cb4Q4PUA6YKz2pu","st_dist_05":"qh2cCGNpaI3HrdC2bDgyMuM2","st_dist_06":"5PfiIsoSMuwIvuhH9PK1rGvY","st_dist_07":"SK8AMkILFlsnvHOY5OW8ka7X","st_dist_08":"MoSWIQRDn3o7nPYpSBe4tIjQ","st_dist_09":"oDxbJXazw5AJ6CeVMhORU7En","st_dist_10":"miSdcjqA02UQ7midosD6pVh2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Y85c0yhaM7fpMbXGBcWrWD0lj4rBx8hgcgUOYdob"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":610,"st_w_id":1,"st_quantity":47,"st_dist_01":"YzQbUZ9kmOGPJGJz4eIrjMpK","st_dist_02":"dnJNUpyMI598PWItIYXmqesy","st_dist_03":"QEB2bvY9vhTUj9TshkQDzoLC","st_dist_04":"plcelgjoZ5deHDbCgorJIs6S","st_dist_05":"VmKQA2tK9QYe5yIzPEGKH2an","st_dist_06":"JMqcShyduPT4gu4MNBj2dVvD","st_dist_07":"3h0JChFtMFtVy9dRnViyzdpo","st_dist_08":"8Ozy5rUSEXNDURLVcRTW9tm4","st_dist_09":"elQcvEDmQcDVHFzRLAK8LlmK","st_dist_10":"VB6bctWOixLbi9N4ctClJ9Ay","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7OhGipdj0Eka2v9OwUNXPUmU6najCCHneUcunf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":611,"st_w_id":1,"st_quantity":48,"st_dist_01":"jKOwpQDYRZiKVmhJHd6BsCLW","st_dist_02":"hTK6O00PwueQ7wQss96Q1DnQ","st_dist_03":"id4qJ8PTUxkaXixPaMAxdqsy","st_dist_04":"yKhsUuxD5chyUjYwlqFLYxqt","st_dist_05":"eyi2HqweDnjBiixVsC7J6dPd","st_dist_06":"xkq8jRAYjMULft31sUYjm6El","st_dist_07":"4pa9G0MwKyesRKN43e7qFlpd","st_dist_08":"AJiMtJsbVKv070ZtqMvqN2ea","st_dist_09":"3C7w3wDQZfqXxr4vfAQr91sK","st_dist_10":"Qbktz6251fcOxoWUXsTYsENF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NSOqCH9AejCN4XJT52BbOMCjyrfY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":612,"st_w_id":1,"st_quantity":83,"st_dist_01":"OgfCiguWrqw92x6UfaowWH7y","st_dist_02":"I9nK3ZvgdW1Aviirog0jFvuv","st_dist_03":"RLLW6WBa2SZhetbUAaUhyrm2","st_dist_04":"dKMVU4U9HuPceb0HFTRziIdG","st_dist_05":"lHfBJnwovXensJCRQ2Byq7HR","st_dist_06":"zzxtEoqSLVvt6Q9idm76OHpo","st_dist_07":"WJBqPCGpqgBdYMMDMwHp3muU","st_dist_08":"cQM9wIdc5uWFwjfzGnK8T2eQ","st_dist_09":"4fOrpRSKefkeetsZ6cIVWEj4","st_dist_10":"OtE0YoabcjMHEEmO6m4U87nM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PSlz9SwoQL3sYk0tNIUzFjWS6D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":613,"st_w_id":1,"st_quantity":56,"st_dist_01":"GXKLvpxMmisK14UuqVFC2SlJ","st_dist_02":"plk9i4b42fhOk2RxFV5oJrWk","st_dist_03":"vsyOqnUCeCG9ZNHe95ud2oIj","st_dist_04":"apRf8lsE8CI9QBAFBFUYHvqW","st_dist_05":"xssbBWzMTo3V7meSY40IHZrl","st_dist_06":"zRoVpQeNPkuBLlE2gWlIj5Az","st_dist_07":"d0G4CxhBsxSZU5kMEhcWDn4L","st_dist_08":"a7HNFUE5LJ4SRPi5MaUNKlbk","st_dist_09":"4gf9uyOm96O4V8B5byTRK9vR","st_dist_10":"WeYOxXs9qCllrAhRM7iQtfC7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"F09cPCGpFUiIUXJVHgq5k6kHEoYK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":614,"st_w_id":1,"st_quantity":38,"st_dist_01":"ro2EhjVIEPgVmvyzlWzlT3D9","st_dist_02":"kG9ObA8OrOSighMuhNS2pimN","st_dist_03":"MkL2JvnZdQ0WtSuse9MAL4Qa","st_dist_04":"xRTq32y2mCiVNEDHF7CfT9NG","st_dist_05":"ytUONFqFpVWw5B4HqWBoi2oA","st_dist_06":"C3Ck0Ac5SrGwHSCkOjREUBl0","st_dist_07":"zQBfi9SUAql3GaWKDVsoLmbi","st_dist_08":"aYLO1WA90hrJcwbBbp8CNiHF","st_dist_09":"rjDAE1wg2FoMXDiVzgueyO0G","st_dist_10":"W3yKMShmrtzpXXSUZD19sGsh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TVOCQ9jH2RyO5mP3fHVor1JVS2t9fasld3fIWUXtTggOV8Y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":615,"st_w_id":1,"st_quantity":74,"st_dist_01":"zlBJKTP7kFin3xBoXmAESMXg","st_dist_02":"1sEEwxkiW2kyxj68TwBiZRd9","st_dist_03":"FznLRTOCSDUm93CNshWSeP1F","st_dist_04":"SapjESN95HvslVQsuJzKNGEE","st_dist_05":"wuIUHt95avi676H8BYny9iEK","st_dist_06":"TificmMVxqKZ5YnnIAN6lqL6","st_dist_07":"mvH2FyGdh3QDzG9Wzt3yctC1","st_dist_08":"AFDHnyORfhILkG1Ck5GwrA0D","st_dist_09":"PSVTVZaQopaCMHcK7mOGCAu5","st_dist_10":"wXfQQpe64n3CqClwxte1DExS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8HGQqHoIf0lKVldHpY94Fbo8heJghHdik4UHAYE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":616,"st_w_id":1,"st_quantity":37,"st_dist_01":"GZHQAGEiT5sD7woxrHpJzm0e","st_dist_02":"L7ecMdxwFZIbWXeYMb5nfyLG","st_dist_03":"lFxQwoNG05nXtEYVBspLucOP","st_dist_04":"2BwsilVz4XL6RcY6vO106JRG","st_dist_05":"C2xt89cnWZyveD8maYJ9gdaT","st_dist_06":"7ilXnUGDN9Q6WhHjam5qeKLS","st_dist_07":"cEEeX7oYNfhm0Wxjdk9ab0dh","st_dist_08":"PhyC9JmwjkU0gKlP4R3lNCwx","st_dist_09":"fQ26okavzcc8RVWqTWWJEruy","st_dist_10":"sKInpWeZJqnxcckftsXoLunA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YP0M77oBbz1kkDUnQ5v8mJqrtn2ScWlL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":617,"st_w_id":1,"st_quantity":15,"st_dist_01":"egRispMWSCF9zg5ey4XUkke6","st_dist_02":"ry3ivNgq8YAMiZ3kL7YtQihX","st_dist_03":"YTk4o00N99RpfOAVy36hJXjH","st_dist_04":"HdcuC2qqCMYcfAoCxRupF1oZ","st_dist_05":"Bs26JeG4iL4cXtVGzUGjUQj7","st_dist_06":"6efC0vs4uaR3Kc4PHHOhvAOA","st_dist_07":"A7LAT2RZqdaGIYyBxc3mrzkS","st_dist_08":"D3TZgvPE7vrmUQFXockbdjde","st_dist_09":"MUNxAwW7SGqe5moCHxMAc4MV","st_dist_10":"u3IXxXibuHlXBmIeREvq0rsZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zTv0kv35dNeoSnLroriginalj6fKNGl6CK9uQhx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":618,"st_w_id":1,"st_quantity":34,"st_dist_01":"lhSnKza8KL6IUdVtApL9WxVh","st_dist_02":"xawZ8afArNnOlkrxNbKK5Ifr","st_dist_03":"9g0s5SXajCRSesN7DpCtXI7a","st_dist_04":"Buyp23CuBMsaOo2Xty7yPZYx","st_dist_05":"w34g5U7uYPgD0RK94fVeLlGE","st_dist_06":"HUALtqyYJSZROpl65nMWp7u6","st_dist_07":"0TLNCstdigI2zLsITBCi6xrN","st_dist_08":"wVwcw3swE4M7szvcRLLvqK2L","st_dist_09":"ljXOZOhEkCXqthDc9ZdZwGyl","st_dist_10":"1k8jVs2THx1VVjnIVnjANzuu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"a5Rv385rrbsBx82jiSlkfHqetYDAtfge2AHUZf9bK20kIjrGe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":619,"st_w_id":1,"st_quantity":69,"st_dist_01":"24EprV9WK41mNbgSSbxmCM0u","st_dist_02":"LgbCSzgGFeDr3E2iOPH4nnr8","st_dist_03":"JVt4QbHFtRtTeb5SQ5PjcdFt","st_dist_04":"8f6qR0swWT6M6VWJL7Mp0y1M","st_dist_05":"Hz66bqrP6mQftNTMmnRR4CLy","st_dist_06":"gb8XKC1zuiUvSBCVVnGbMZNM","st_dist_07":"HVK8qblspQyaSD2JaRehmRP0","st_dist_08":"VpKE9zHEPGSqFFSGs6wATN8o","st_dist_09":"vpE4y0xeGcfe6emDDBXPPXqe","st_dist_10":"C7x8kpsxZOd98b7zaSh0G9Qm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PMdlkSzdhkdf6zZttbODAZCes1ugIR13ZOYIESbeRRZ4b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":620,"st_w_id":1,"st_quantity":22,"st_dist_01":"wLZHVspX9AD3eCmOHojbEgPD","st_dist_02":"1PP1NfoikSYQZ26qR8G15k6E","st_dist_03":"QrOidLBZVXW8VJWNcbgYzfyr","st_dist_04":"r8rvxd6mSYAOisAfcUT6Q7D9","st_dist_05":"lGvvwhiIL4z3fNxtMVejZhcv","st_dist_06":"6VuUvG6Vh33NK7ASMh2Vh0ay","st_dist_07":"BOi36T7hbdd7a9nWCaEltwT0","st_dist_08":"f0k9wCPWmRbj6TzMXABLHugl","st_dist_09":"EMwx5Oh9WhabFpdQbDoFiSw8","st_dist_10":"szGoAJNFuFpKR5O9YsC4rpvM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wd2tqyVdPPJSiF6HTAas0qVxKLB26Ro"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":621,"st_w_id":1,"st_quantity":19,"st_dist_01":"0FTSIoV2hZrHKhRUG7iHfLZc","st_dist_02":"wHptdXvirgaYB9cvG088Cn9O","st_dist_03":"jYLMpekuiyWa92VJG5aKz2A3","st_dist_04":"VgAt1f5vO9HWcItq6wsds20f","st_dist_05":"SMesq1OMPw9zmgr05pvPSLcS","st_dist_06":"UjFqfOztq6lCA6XcnyBaRgxL","st_dist_07":"ACUn4S9gLlBWoqkaKWdKbG9U","st_dist_08":"7fBkkx7rTO56jl8BMcAbkpG9","st_dist_09":"zgPNCn2QoG63BNUPMVZtfLw0","st_dist_10":"sl62IhIvkI90bqzXDHVawZwJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7PcqMOgFxw6GiIFhFdLZOJDXyudsLm2kfxfY5PJo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":622,"st_w_id":1,"st_quantity":98,"st_dist_01":"rtw3HUH5fEMRwtI2N6UrJgs0","st_dist_02":"VNOH6ZAGgRRO30ZcXfYrRSGI","st_dist_03":"wZe62vqdv54tH8DeCofUIZuZ","st_dist_04":"JNVlC7F2xe1R9FZr4V5P71yf","st_dist_05":"MikcPK7VOBqmXiCmzkiyDuRy","st_dist_06":"dPcdFYpY6ukeKmob2TQV6Zwa","st_dist_07":"qIE8COgRC0M0ZYqUIMLVQ0PH","st_dist_08":"OlmKQuv081dTD7GS4LIw8elE","st_dist_09":"9lOYqjxoXDrunrgylHak0k6G","st_dist_10":"f7jeSM8vV76SfnncexGinSe3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nZrBAokBxipANLoDcSslqAapS7ysTcgtEcJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":623,"st_w_id":1,"st_quantity":91,"st_dist_01":"l6DrljgWtGlRyTx6ulUFsgWR","st_dist_02":"LxdoOsqTxXWwV0gEVnS0KuUn","st_dist_03":"BSSHtGeCLNiyQaHLhD2U6hGi","st_dist_04":"5jxPFuHuPSDve9tceSO9fRJn","st_dist_05":"2lDy3OS54jAkQcZLLFcf7SFe","st_dist_06":"sLVFq8I2jFmtv9iRkKyYTADU","st_dist_07":"tjEQ5bXUZlV1CgcEZCFilftj","st_dist_08":"nB548OXfy7s4G9YIYu7z3qUT","st_dist_09":"qdfcluxRuUFloP2Qwl1JivfO","st_dist_10":"P8bO4yFqtD67OWftOmozwABj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ywHQQvcuuP2efgHSVVq6klnSSv9PpH157EEFE5OAMjSiUkl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":624,"st_w_id":1,"st_quantity":53,"st_dist_01":"QoZfmzyTa9Ruurfv848Bflna","st_dist_02":"naKMrJAhuFaLJF6ZbjZH8yH6","st_dist_03":"B9QOkZtiCEcm4PHAFIY9pPaE","st_dist_04":"oMRNN6Owg0NZ7ShfmdCjekra","st_dist_05":"UsxmSkF6LTGvVuemQgNOm5uQ","st_dist_06":"DsRocpH1iVfV72LpkXCyqy26","st_dist_07":"Wpad1UkZ1yi6XfZOzwNshxxC","st_dist_08":"vDhPgrn7Q7YOo42rTIo6Zmri","st_dist_09":"ofX6Jj544YHQwB3ZUI2thoPu","st_dist_10":"yMOZCYR1EuK3pP2wXrkVoDnX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7wVMBThCIXdyyOwaDu7pSoC0nEYe5F0sD4ljrNXeOIF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739239,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739239,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":625,"st_w_id":1,"st_quantity":39,"st_dist_01":"lwb5ROTHlTGjjjZJ6UkS5Kvl","st_dist_02":"8THv221YiJrlBY3fypClVq2x","st_dist_03":"EyOQMsKdWzGfzq9Nh2OxqYWu","st_dist_04":"PbarsEWdbpIeGEdYDEosEtaq","st_dist_05":"p0vEDSzslFwiztEVF1agp7uH","st_dist_06":"1dzeQGIf8WLDauH3EK1Urcoa","st_dist_07":"bYuh3Bj1uXvMt2WNAU9L5q4S","st_dist_08":"3NagAT9p95lsLUgCZykbrZNA","st_dist_09":"UqYNp6A07ZImWracvOjZiOmg","st_dist_10":"O5bBNSqcDKvy2wq73YkzSeJo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LigvRSPQEdQHnt1cWlt2BCfDZb2BE7Vw1TZLWPE6XPkqE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":626,"st_w_id":1,"st_quantity":84,"st_dist_01":"Shl4dukzQifhNQd7v2rKiUg9","st_dist_02":"ZjyubLKNZ4h2NlxVFRf0Qgxv","st_dist_03":"fH9nRRO0zN1tGib4TYtUcrgm","st_dist_04":"ELIduYbNVTjN6SDo7HCTnh3E","st_dist_05":"2KNW23QEMQCPY0Ef0XQA0Xio","st_dist_06":"7IpqVo7LLhFZRbIk6x2Df3dc","st_dist_07":"qom9hKxJJbl959IOb5XKNsvp","st_dist_08":"muqh9tVmDsMSdaxbhCECm8ae","st_dist_09":"CM4ht3czzzZb94jFo6mq4CTm","st_dist_10":"R3tgq6GnDbfk8yeW7Jate9Cj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GiyEuTJuUffdeo3wo7ulETATjeRkIl87"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":627,"st_w_id":1,"st_quantity":24,"st_dist_01":"EkhFjP5aNlncEkkPOA4z2IJM","st_dist_02":"trlZoLG0f764fUVmgAJt56es","st_dist_03":"Z0fRoNZLTZJZAyQoAd16HOwr","st_dist_04":"Vita5Q34JJkntrdr6ghBX8qP","st_dist_05":"YXO9i2PwUUhIis52CXRdKBPJ","st_dist_06":"3cAZQzYaDHGjNVLPlNoNHAgS","st_dist_07":"4c8dvnjb21R2vYeaDdYcRgdJ","st_dist_08":"VygKz1ujjkZgx2PgQWxQzVuL","st_dist_09":"IsOfwrQhkUR1shMZnKhqugs7","st_dist_10":"Qeb6t8iiRnW0f51ijPQLWf2U","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZBFrjKeXgEiDzwaDW6jEKFqP9originalA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":628,"st_w_id":1,"st_quantity":77,"st_dist_01":"vvxmKdTdqp2xg5d12Xjuh304","st_dist_02":"42DNGNIeAAvZB3rpBWXBlCzy","st_dist_03":"XGaevgdYPDsnH1FxMxeNpOr0","st_dist_04":"qr1vMw1OuuVKAuefxBS2tNXG","st_dist_05":"seBn8ZO0GHYZqMaIeaxeEkQ1","st_dist_06":"KmiitTW47bh60B9bBHDl1AJs","st_dist_07":"2cOofdW5Sg1my6zKu3FF6HcH","st_dist_08":"c6G4LoDvlE6n2vSOyyAb13F2","st_dist_09":"nnHMGZKA5VnbWHrb4UiFach6","st_dist_10":"LRoKwZVG8gAo5b7QJzs5a48f","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nnQ1bJC5DzJaS1JBm0eIcv146RZa4fPFhbkF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":629,"st_w_id":1,"st_quantity":36,"st_dist_01":"Zi4hwhdBsDe2stScNtFcbGWc","st_dist_02":"3EtpW8jbHH4JAjSL5M9l3IOq","st_dist_03":"13Dc91KR7yIAeaTUealVldSc","st_dist_04":"uq2ZCw7UzBwXk06v3qY2rVBg","st_dist_05":"dbH9K8aY22kkc9T1YOfSq3jB","st_dist_06":"IpLnc4OrDhuNV5w7NkvMde4T","st_dist_07":"3Tu7xCVPGDZZq6L3u4WeYrpl","st_dist_08":"wOSTtaH8NRdLiWYwXsJEffom","st_dist_09":"dgIBZmgQYKe9kw2BoMgdgRWy","st_dist_10":"xCBNv6Qnr4GgWd6e57smrBBZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JhF1XvIDwnJdyl7U4sJ8UQcu35xY4JQPOCI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":630,"st_w_id":1,"st_quantity":14,"st_dist_01":"gIcGErZHiCxlqqbBAx1cdBeY","st_dist_02":"K17Ma1YM9wGAncTUynKwAm2p","st_dist_03":"8JBQUsunriKCqNnDp2nBPjfR","st_dist_04":"cKL0jC2CQoHn2jHBUYQDezFL","st_dist_05":"npn4Z6Y4BdrlRXtK58LrLlWQ","st_dist_06":"lI1PlBzUacdNATFbqRyXC7xk","st_dist_07":"hBTqFm5pXAJ4x0E8FSAl6VIw","st_dist_08":"walkTlKHCMlBh2uyn4CoeY6v","st_dist_09":"OaMRiVKpbfzUp1gLBIYKCGzf","st_dist_10":"1uIPdECHRNQyJwM0Klg0JYED","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"40DbU4l33YDlCF2SS0rr9tMtpmpKUNjjA4SL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":631,"st_w_id":1,"st_quantity":69,"st_dist_01":"4H4ojewpjFlbwwBGVPIDEnTs","st_dist_02":"rCDgi9IwesU3Uolbb4whLftm","st_dist_03":"Gx4O9LWvHlgz8Rs0UTMbJT0H","st_dist_04":"qls5uRcKwBbvs8aYWdgidata","st_dist_05":"OFczAYSbor1GY6X7XeDvStIn","st_dist_06":"q9KLbBwZD3nA4EcQGaXWE8sE","st_dist_07":"W1CKqd7ASeTeud3NIcTXGEsn","st_dist_08":"2GhLpQTJl0ITjWZ0pw6MlJ9W","st_dist_09":"ko3seaZ2fyZVchIjFBdQY1Hu","st_dist_10":"ZbyFqrfN9HFNa37envSKCajo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"E9ZufsmcRo7hx5Lxe0CfoIgXIg7Bo0u0yKLj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":632,"st_w_id":1,"st_quantity":80,"st_dist_01":"Yc6cTNezYiPXuvhCAqZ6QbMw","st_dist_02":"VvVCcz1GQtM9fZtDdGMzUJ64","st_dist_03":"3vfVgLVc3BUY8iBEmQHTDast","st_dist_04":"WQQ71ioYUREn6PrpEzaVEWDH","st_dist_05":"LfoMmnUt4bOI2HQzcSjr2Mf6","st_dist_06":"wBYMe861KiELxbYP9xF25RqV","st_dist_07":"wTBvfFnt3E9A0AlbencjJR9O","st_dist_08":"DtZjykFCVF28bNpR3yzIxjqq","st_dist_09":"SleEW7zsSHCgUVEEqmrcf4ei","st_dist_10":"XmyX9jXAqYoNdsbOtY0lmmt5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mW5GwTIRIUsiW77cEBz9mp7hfKJGhe48V1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":633,"st_w_id":1,"st_quantity":10,"st_dist_01":"0T6Op5NFfAIz6cVv7Tyx6Z2f","st_dist_02":"Ml3jnJgzEuS6mpQ7qzKyb7SP","st_dist_03":"gqXBUnnT9nSNP0zux1w9I5c4","st_dist_04":"vw0YD9ikaecWgXRPy0VPesfi","st_dist_05":"oBouwrwaAvH1cVP4i4YgAyMs","st_dist_06":"4OthmP9QVF4faQqm20HRz4zn","st_dist_07":"PYAPIdLMXG3Crwk0d0swBcJx","st_dist_08":"qaXJ15lPcPOZ9rmUYZW5xkWO","st_dist_09":"Y2mksPypIm7vbSa2m7zxHjGT","st_dist_10":"lHEGANebwGdhgw7CrBn84mF4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"87IVXpVEkSPrQnvlJ7QWsNkF5N1i9kcCVyZzwE3UKWqF6FW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":634,"st_w_id":1,"st_quantity":84,"st_dist_01":"2GRvPsAeW4hF8UqLtnLRakqQ","st_dist_02":"ri311IwvypH4lEpRRKzlsqZa","st_dist_03":"JH7ri6ycxi7QUDOhh5bChlVE","st_dist_04":"YDKSwzIwmGEHTwW52gbmWVHm","st_dist_05":"3thhJ8pBhJB3Ll7bBWSCy08Y","st_dist_06":"MVX8P8jrZqSwZI8MnZ8XvU5Y","st_dist_07":"3II2Wx8avUaGqIVi6pdqiazE","st_dist_08":"ZFVAGKEWIir0pPqT4qCwc88S","st_dist_09":"TtGUIjzPoMlGm3TA1jVc9JDA","st_dist_10":"xCgJKGTyNxNzHjkT6uCxbr7e","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"s7voYgNHrnSXi3VR3ZGC8YBgKbFPzrYnTIZThQkeRyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":635,"st_w_id":1,"st_quantity":28,"st_dist_01":"Q1cyHJMqI8eczBaQ6eGgb2hx","st_dist_02":"Li9te6yvSzYGltWpLMcAa1oU","st_dist_03":"8ePajMcUbZVaNYNbpVrPeGKX","st_dist_04":"pFrwhOfp1CjmkKekJFGwxkYI","st_dist_05":"ONz2J3JeNSsTQhw5jY4jqSVs","st_dist_06":"tmgyn1snZiUeyDcNfd67Ge8v","st_dist_07":"drk8O3B6nfMxa2pa68sGTPA5","st_dist_08":"WlEHQ1CFXGhYt6T467TA4OQM","st_dist_09":"Vwxh3daauODd6OPQ2eNDzcZN","st_dist_10":"4j5Q1BMPiSFewWxpDdletYCg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jv3CMdwS99BFkl0ZHev1XkQsmTj3FlxyoRja1AWv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":636,"st_w_id":1,"st_quantity":15,"st_dist_01":"D1jYMzGdrAytrauhPr0yGeNH","st_dist_02":"2AxadWUoRe50g7mqewAqy5cF","st_dist_03":"xOhIkV2ZvefosciKd8gPnUAF","st_dist_04":"cF8NvMLbQZ7j43b3qSpLk8Yp","st_dist_05":"xs0VshmU9upytBBrCHrTcQmD","st_dist_06":"lfnENEPvdjzBXrHUjEpAvaJs","st_dist_07":"Xqer5r35h5nM3ktkPNqeiDLh","st_dist_08":"wfa58YGHPILXHiqoYJPmEpG9","st_dist_09":"dZJkPmmNg4uZfR47liIehflJ","st_dist_10":"EGbNd0rLXtSiOlMQUi8EYpY5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BNhdvjxfYlvsOVdcAxCHvtzpVt5FYxiPAElQ7npUg0nksjqH2U"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":637,"st_w_id":1,"st_quantity":25,"st_dist_01":"jo4XrFg4HYKBMs5aDypa1ZfR","st_dist_02":"2hZEBK6cIKbsDfp8YpAY0EIt","st_dist_03":"rHeLfQGvk37xZYEQpe5MGCXK","st_dist_04":"EoDqfaaJyQQP5SVq844crIvu","st_dist_05":"1xL0wkAIa5dnkZkCFHnWmAVL","st_dist_06":"x0dZAnJu1RGrtPSTm6zeAwGV","st_dist_07":"mPMhSKdYEbUB42JfJ8UbEcjS","st_dist_08":"9D6oPrOCgvEDdh1sir90MDi4","st_dist_09":"q1pRayqRU30TQdQspDlr6MK8","st_dist_10":"EiL81vOV9Q0vhVFWHug8xRht","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7y5Y5lfSFPUzIKzpOOB8oajGqb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":638,"st_w_id":1,"st_quantity":26,"st_dist_01":"rJhtEsHyR91omB1IHyYTu0Ql","st_dist_02":"uLYabHNRI9D6lhzf7zviXw1k","st_dist_03":"sszNkPLhWazEjwaxgs0UqT2D","st_dist_04":"dqjpXsawfu8vQjApKdkqeGsi","st_dist_05":"EqLVOvjXrv385GaCSHTiZX5V","st_dist_06":"FuDpwMy2izeF3Dqx8u4AnxXp","st_dist_07":"i0ykmhi0UTxHqCs6fTpcCmIw","st_dist_08":"lqrXKA62BVIlDN6AnlyWgvcG","st_dist_09":"eeExux3XDUZhU8qVcyIuvIg3","st_dist_10":"51j01qdHNIMvH1DfICa3uTYU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4EQDcQChZpOPsfnq5wBMFqsYmnO1BasQIbBW229e98ThJvMCre"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":639,"st_w_id":1,"st_quantity":93,"st_dist_01":"eJih8uR5UDGcBlb2QYVs7tVD","st_dist_02":"Qn9AeUPehRAD22iyLLxEPKHV","st_dist_03":"2V1Topb9fyBxHPQQonWE37xp","st_dist_04":"mshMZu9sEG4mqlYeyNf6e2g8","st_dist_05":"8P3nri2DwYZld4K42Mpwv4cc","st_dist_06":"y9MZglo47IcRDyMoJ9Tdr2gs","st_dist_07":"UAysQuMbg0UcIVbyj4HshAo3","st_dist_08":"LLW2E1EM2pXZ5U0Mep0i8L4w","st_dist_09":"opwVsxE4zIoFDipHicHPEbwg","st_dist_10":"JiShLGay63J7LA3g3VKleHeR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xEZVorXKAlTHLxylGXVvy5qYLJrULs7gIa9G72cXavc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":640,"st_w_id":1,"st_quantity":13,"st_dist_01":"fPiqTZk008GDg7zjkk3VL6DL","st_dist_02":"twTbmQ2BXvAKVhhnG9DIA7MS","st_dist_03":"jzClS3TiBlfHFJJg9lUdPGqn","st_dist_04":"ABIFHu0qlmUNZZHu2DwA659s","st_dist_05":"pGCoGVXdzXmtyAUcbS3I8l9M","st_dist_06":"DWVn1h8l0vieIxQlYC0bWQmZ","st_dist_07":"lAaj3QlU7f0Q3iM8ZjF1L4nY","st_dist_08":"g12qLvCp9DGy26LuTtnVBwCo","st_dist_09":"dYPpsPrtEfuXSQYU8v1Yg4Jy","st_dist_10":"PW0kIXSY560G24cOc8ljDqTH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"V0adsCJ0hLKhcRcP7sIzFzh4CJ9Gc8BoriginalKAeB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":641,"st_w_id":1,"st_quantity":19,"st_dist_01":"XsgL4xiK6XxWtUV1bOkWaB7b","st_dist_02":"qbxYKs5EcgT0xVhHOdyRmGsV","st_dist_03":"JggMgfWHLdvGb3D5xwixyfMz","st_dist_04":"ybePpVY8JeLVeVdrCa1p3nhw","st_dist_05":"J6kENWoAC0MT7fEkYz75IsQx","st_dist_06":"kxqqpe8u581maVCatYCAF6ap","st_dist_07":"aH78mScczYVkw7Ba3lVuANcI","st_dist_08":"ZDrUoj1ced3euEVs3lHYKpRv","st_dist_09":"jR7bCM2oHUK6jEbCaCDInuvc","st_dist_10":"ekTO35WH5ys3MgcplYustncf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cPeUE5sXHCm4G5urdDBFKq5ML81K40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":642,"st_w_id":1,"st_quantity":56,"st_dist_01":"wSyvs1aMhHzImWIKhdiabc29","st_dist_02":"YpqiEkQKACqKziB7MAVCAvjE","st_dist_03":"590v4TFtaDuilC0vhffyTM3H","st_dist_04":"ye6xZhbw1xlSzibL0dQXlrDi","st_dist_05":"nnvK0HWAUhFtSXnJZX8SVqBm","st_dist_06":"xoI7kPuApMQ6vRBjfagVpQWr","st_dist_07":"QwnYJ0pCw9Is8gMHXqk776gO","st_dist_08":"wKjt7m7O9gceqdWQnyoux6UO","st_dist_09":"2BpZ69yM8cNkdGIk08Y635vu","st_dist_10":"lOIYeAW92DyDVGeKcSY2MqTz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dEBa5QrNkqSibu2IQ4U1mDJ0g2pSFBi6E5MFLbm3i1J7UqLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":643,"st_w_id":1,"st_quantity":87,"st_dist_01":"gEh9jlZs6cauJOVwBKupSvbC","st_dist_02":"WYkT2xIkfg40PoCqbP0bt8zA","st_dist_03":"xR3D9JChDw4CezVbb2owW8a9","st_dist_04":"lYRDsNCtrIogqTmLE2vGQI22","st_dist_05":"VSL4DG5BoF3kVfC2ptHgjBRu","st_dist_06":"Sin7VVOHXqdiHcr08vRH9BtO","st_dist_07":"mqnckGpNvCMIwLHz2QifXzkY","st_dist_08":"DP1vcI2GGPeRIdqBWQpSeXPo","st_dist_09":"D5SmZOjurOx0R7gI6awdFqwh","st_dist_10":"Au8vtrR1bJxTxz7HLsFKQ2a1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4rqVVpgJfcfOgeEokbuTH6Xt5L8FC19Bbac2w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":644,"st_w_id":1,"st_quantity":91,"st_dist_01":"h0xsK2j1JLvm9TFpwpksLXf7","st_dist_02":"uqr86WAHOPmZZ8dspzuDT2hC","st_dist_03":"GgWQ0pP4y8NUCeiDugkBnJqK","st_dist_04":"OLFKcSOVV6TmhKq6uxRvvBAr","st_dist_05":"cv1kYRg9TSCZmoImAoI9f276","st_dist_06":"vepkl3u4tfTzFQGk6HnwOsKn","st_dist_07":"I4BjXHWibdMPrPmH6XQL0i5m","st_dist_08":"pFRNeBwUteAaluxJ1IJ6MJ2V","st_dist_09":"iqLsRyRQLjOiG5Q38nXluXAq","st_dist_10":"PngawFccZ80HWd2auItqfM1S","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"n7SlUEiBjAkgNbp0ebtbWQfpV6mwNGbQ6mgeNd0eq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":645,"st_w_id":1,"st_quantity":41,"st_dist_01":"YNg7LQXVYCON8GlWKnqLBzLA","st_dist_02":"8tpjA8EmJjJbWvLn21ng9PJN","st_dist_03":"gCtAMG2rIQ2mFjQ7Cb7yxmaj","st_dist_04":"LsToPUiBt3zkXPow0GI8AIKt","st_dist_05":"pP7M6VkGmedpN2xENOjvHVkm","st_dist_06":"rVirrxQeuifVo9VzTj0bNRYT","st_dist_07":"A486tkE3HDQyMQDFbIRBfCTa","st_dist_08":"HW1nq11OvTb4qLFtqzPsnTxc","st_dist_09":"zzGIaX6mYvi0eywQumBHAO80","st_dist_10":"2FaLDVEcNRSrge5dQ5kc8Fi0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JtLtp18060MX3KAyKd81QbJ9b78MNhBnA2ChRUpMdIasyxj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":646,"st_w_id":1,"st_quantity":26,"st_dist_01":"MPr2OOyGEw9if5ycCkNM52to","st_dist_02":"NzcevKMaBgA3Ogh2Zv7iR1YN","st_dist_03":"vsb1HWE1kMDbYH82oCYhmh0M","st_dist_04":"K0rlynJEtPW6mBagQzy9q16y","st_dist_05":"wWM2gRLc0ZOTEMijjK7RuVpX","st_dist_06":"adWVNnnwlhLwsffGuqtrxgoY","st_dist_07":"WmxXwPoN8YiL0s5NpJIgeGla","st_dist_08":"sd8sDQQhO61G8IhCc0QcpC90","st_dist_09":"hhx4um0vHEd44dIwmsM4G2F6","st_dist_10":"aW61uLnjWqneM2DMgzj0lFi6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"13f0dk6qqthXVAeOdnnudDMhSSFAtFbilVFmJ7FZ7QkfCDRi7Z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":647,"st_w_id":1,"st_quantity":50,"st_dist_01":"sK3F6azqvYuPBcaRXjFicH5J","st_dist_02":"KN7rUbjWkdjOOb9jP3IkUelo","st_dist_03":"hecvUDeJQKLQClxfDaANLXfq","st_dist_04":"Ozo1WKlnOzuTuJsDkQiic8ff","st_dist_05":"whYhrzGfmZ1fXSVM2cxmGZuL","st_dist_06":"E1oAaDSg0JDUeEki6xAyr2pO","st_dist_07":"ccbFyE3LooKRRiVgYcffwXvT","st_dist_08":"AIzSolkyTZmzMOJvXgviZM1x","st_dist_09":"YRFwghPzldwB0QBKd9vNWCHI","st_dist_10":"z6xFLnit64ciek1F5zDjeiaH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TbHRlKwFIKYPbEuPCeWjjXYwwx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":648,"st_w_id":1,"st_quantity":14,"st_dist_01":"7FHJE5nKqZXYTPYAMLJIWaie","st_dist_02":"KDaeYARJT0lrJSMaduTciy6j","st_dist_03":"2tUwydrwV5tpwt7YcclCc7tl","st_dist_04":"wBb0Y0HbjmMQxh7Xm0z86ct1","st_dist_05":"PqFkURSVlk5ajV3FAVjhMoAg","st_dist_06":"yEHE7v93kec2FCZ98W1CPjwl","st_dist_07":"ev89lzGm1ysDp403r4yQs3ou","st_dist_08":"2KuqmccjjQfmV6y8rQwCB3Zq","st_dist_09":"7vOR5pUyIA6sLKX59ygQ60X6","st_dist_10":"nnFuXHNwlqm7tySV83yO8yKz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DmzckuOlnfWzcw1bom9EtwXQ1G9Ro"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":649,"st_w_id":1,"st_quantity":91,"st_dist_01":"Xs7J0FykY9HkJ1NlDjihJcwp","st_dist_02":"NbbNywuYAxP8pWKaeYBOjvM6","st_dist_03":"1nSBARBpgOK9o5lY3Zs4Ld23","st_dist_04":"Gjl9kZ8sZkscpTGPgF8QYZt7","st_dist_05":"0eCfpFT7C6H0wOCFv1ETpN0Q","st_dist_06":"MsUNZlxS5isSrsa7jXvGbClz","st_dist_07":"MeP3MCXQgq1lg1n5SKnIphsm","st_dist_08":"kJTfg2HxyH7ccGSAEhcwz30r","st_dist_09":"4oTH4erKmLAxNTx59Udv3rX5","st_dist_10":"EuN55vGl3I0OCKoBUV27TCDi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B4wEsvwaX2KoWxt6yD6Ue4x0B3iuDfqtk0xLI2NhK8nC5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":650,"st_w_id":1,"st_quantity":34,"st_dist_01":"L6HOfPZq5UHjJgNYhBCUL4be","st_dist_02":"HU2KQPdL6NySgvRi5LwquZWt","st_dist_03":"xxnBRH3xzcpPcj3prYgIsNlV","st_dist_04":"tCPgGKJsKyViBm45v31gpNac","st_dist_05":"p0Urt66PhWTKKD3uCoSaCEvF","st_dist_06":"2aEcasdjgJ4NhssYgV0qzAYF","st_dist_07":"WSu2XjkbLbLb2jnUhMQ5G4uX","st_dist_08":"1L11rec5n5RbRuj0rJeWwo6D","st_dist_09":"shUyL7wdB5SrLRpIj72JNM4F","st_dist_10":"bFiiEWCvp4DBgoRJP8FD61BH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"D2h5VGUs2oUXYiwzV0JAYFBfQLlqSUx7jZhDX9FfEgblf5grzn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":651,"st_w_id":1,"st_quantity":67,"st_dist_01":"s5Cd8yTA28vvj1HATEEz0d0R","st_dist_02":"RZmWI0KXF4nka342TBjrUlDt","st_dist_03":"ayqBOfQ7K75lVcER9rzbqtuM","st_dist_04":"zWtD31tT1zyFPTR13wuQ4Fqq","st_dist_05":"FuTBrMyHmJWEDzSU0nS5AK0p","st_dist_06":"2N5ChbkBVQhk4s2HQ8THjrBn","st_dist_07":"xplFu9DbdyWDP1lxgvzrI5xl","st_dist_08":"gs49C2nvkZ4g5CLq80U1omSR","st_dist_09":"vCx0kqvHhKz67Y7slX7DbiZQ","st_dist_10":"PCrtyZsvFmU7Ks1Eewwj20jw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OsIDf7fpNDIwenbrCJjsSW81hj5gVS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":652,"st_w_id":1,"st_quantity":20,"st_dist_01":"UZCwo4jMrPnrtseifpKR3tob","st_dist_02":"1MA69wxDrEn2nFW4J4gB9SRu","st_dist_03":"j8OdEHo5Lzje7t7Oj7vF6fpB","st_dist_04":"yMApjjLy9TdyIukYrp1ticLu","st_dist_05":"qgpRx8LjkcVRZ5kkUbysqFZk","st_dist_06":"LE6urJcGq5FmqxeVH41Q7fxV","st_dist_07":"NPGywz2iL4HekV779aVnYnoC","st_dist_08":"EFzenp7ddxlJmcTyNPGBKPDC","st_dist_09":"pGctHooE7Zpy3fu2xYiceiPK","st_dist_10":"FXrNlOk3lC8MuJKRqSFRLe5Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UIKkVPm98lKkQpsE2ZKcWnOi6XDJSrWVyqHBi0vN6fg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":653,"st_w_id":1,"st_quantity":10,"st_dist_01":"uNWH3uArzvsFXh5zfFjwpFVm","st_dist_02":"Wl4wlIUCy09SR6Y9uMuD9A3J","st_dist_03":"HLMB8yD8apw2tfN1UM3Rloop","st_dist_04":"szFe5O0jcbFdNUqEPZdIlSFH","st_dist_05":"IdhQLSyEMjJjWYiyf0W4jyLS","st_dist_06":"WlGIQX9wwhfJvycLKlg8HcQM","st_dist_07":"XrlzWRGlFItuKlaGvqgjddoV","st_dist_08":"pc0uwXaKlz1c5rU93JWmIZIK","st_dist_09":"iOYFH7itkKlf6krtKpABoOI7","st_dist_10":"QRTRZVZWXF6pOS4AzksuzCuP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wbJtZlVtqZwG5DgtsAD33hbVtiQ2zBmZgmRN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":654,"st_w_id":1,"st_quantity":36,"st_dist_01":"IdAJuHcmZKBFgZCnz8SZWqtc","st_dist_02":"mVWHhkd16lTaHWYPcRT72AYx","st_dist_03":"iZ1mCz3AB5PonRLWs5G7q3VC","st_dist_04":"wROZ4nKuAwfjifwCWVXQdBIg","st_dist_05":"BpombGtGPXKJ4LbbPggBL2JE","st_dist_06":"gV4YQ5CIYqmpRWFnwQAqxOPf","st_dist_07":"1a8dt7NtsRtNuJ6U4VmQWg85","st_dist_08":"4AuKvVoo5rlLBI4WNEB45mkt","st_dist_09":"OpcBhji4UITsTaFUA5iwdzWz","st_dist_10":"O5VrESS0AnrHt8xIFxp5QxFv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1CULwCXfYEcFM3kjoTDz46QMl4R5NyTNaS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":655,"st_w_id":1,"st_quantity":25,"st_dist_01":"v2C8nzrYtMM4WwrECouPseZ6","st_dist_02":"ouKu7cr8Ygt1WnJeKdn3NKiK","st_dist_03":"zNbc0gr3OJdQJNHw754OJycT","st_dist_04":"KoRzqVPSKeHky6WYUjGYQYVv","st_dist_05":"6nZg1dZXhWkzwWsDdxAMVtPY","st_dist_06":"WmWb5eLZZKB4qHVV7zFcmVlA","st_dist_07":"yEq0xr7lnwMqZPIsWXKE2ZNe","st_dist_08":"14CkAXvY6ZG2xpcDBgkcsuUu","st_dist_09":"6rrXJSpifTjyAN3qOvdWnOHa","st_dist_10":"QhkdsciVd1HmNKOMhsQFzPSs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EtoIDNswtIUADIwY2iUpfQsUb2DQgTqXhugJ6YX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":656,"st_w_id":1,"st_quantity":40,"st_dist_01":"W1eYQZQFDNSAwH8TRZULXWFL","st_dist_02":"MG6MU7NjxlQnVvaoVXwTeqaA","st_dist_03":"yykIwupr66eFVvFs02mn5gmP","st_dist_04":"zbiVocsb6bmsIN5P4RzDh6oY","st_dist_05":"4OfqUvovIUSmaO7WjYFMbQsm","st_dist_06":"eHfzoJ4XELmd0PyF94SHEWVM","st_dist_07":"QMEsN2byBYQJibFKjDqIto0R","st_dist_08":"Uowb5CRSN0KmsUWKMJqV4WOp","st_dist_09":"rFH7xIoKYkvl5EQ8dJDgUZVW","st_dist_10":"XhUDfTLzIdqwEEAKGUvzm1Fw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2vYJITNrB5yr6vLeoXkSgQznPUIeQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":657,"st_w_id":1,"st_quantity":37,"st_dist_01":"Ucmxe1K57hbUQVxZ7zXN0S42","st_dist_02":"2EAjI7ZCFY6SYNt0NnyAGdPD","st_dist_03":"pldhXWYY0FABjuQqrDUmpt57","st_dist_04":"7MeWX2Fu8jdlDsUuSYe8IFkd","st_dist_05":"u1PYBwlDEtZVPL2dUPanCFli","st_dist_06":"LDR8YIyrbKPwWNN617ExvZo3","st_dist_07":"TmqjlhsGskjDCLvXJ9VKOQuL","st_dist_08":"eM2PuzVit04afNXnnxamEZZs","st_dist_09":"vzBACCKzhyDU2MJmR24tjh6D","st_dist_10":"LzDlr7ojFQoBNVVR8s6MG4wZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6xadnyML3Tgqn6NIx1jkXysGVSzvkl3cH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":658,"st_w_id":1,"st_quantity":38,"st_dist_01":"sR8DQwJcK7C8tsN6Ldq3FJCF","st_dist_02":"YUxoKdEUhg5sJh53EKop8isp","st_dist_03":"DyxSELW8mA9ZeZ3honKcj180","st_dist_04":"qfcEHpse232K8u85Q6QiHvUf","st_dist_05":"uanP1vgvlvh9Jo72ywwTkNZM","st_dist_06":"QOuS7PbSIL1R0pdeHDgt1ZPY","st_dist_07":"OiQGyuo5Zi74h56h1a8y44JD","st_dist_08":"SiqeUOu5Lvq0dofQfpWo0zza","st_dist_09":"XNhYqE7ki073gyIsKk93BIEL","st_dist_10":"0akYcaviJbXfnKCFPsKYYAsU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v6cKogGINZqRdYCOXthS9T6wkfvjD6iIvsdAevrO1CUnmOFSX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":659,"st_w_id":1,"st_quantity":93,"st_dist_01":"uIhfb5gXFnqZfMeKPxOivhyo","st_dist_02":"AqQbIT49tX2GxBhcgbpLwZKs","st_dist_03":"Tf8TJZyioGDDuA0Ln6EHe3EL","st_dist_04":"j3EZ0WqhWa7kCcQEPyffKgmf","st_dist_05":"MZBKm0WsqLdO0k7ylfoOuSao","st_dist_06":"Pc7oKIaDz2Ug9LgY3ewj7eHa","st_dist_07":"bpcwzQOxTxqWlsxSL7S5PVAS","st_dist_08":"wTxj1Fp98NeJW5iG6dhabV8q","st_dist_09":"tcpZDfkExebGASjrmdSkVrXc","st_dist_10":"cDNrzbwEcorFRPCqHbJm0RCa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TcodMnFy2hrXWLD1TPbb1gmFPGFVFc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":660,"st_w_id":1,"st_quantity":46,"st_dist_01":"XWe9ImAa3HwEbdlEQlfPhFx5","st_dist_02":"OzmAmcscKaTWF6LQjA1V7Uiv","st_dist_03":"QSTc4QMB36oi7q3PKzKh00Tw","st_dist_04":"7qw1LX62G4jrHZraDd3HWkHW","st_dist_05":"fG9hU8N9giofkGgag8uRPE4W","st_dist_06":"xM3ABpAkTNDrCNpt1Qm69Qzb","st_dist_07":"4QIKIo9mEsh1KqjwusKPXAGM","st_dist_08":"F2FAdHJIptZIOaGwtx7hNWhE","st_dist_09":"r4ym7tbl6VNlP2QhGO7da0i2","st_dist_10":"k2eXXEqk2dTAmh69VJMUJx1q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JSBe489ygIWnSEF1pxxy0up58MqwpGyLodQejhfoXI1z3va"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":661,"st_w_id":1,"st_quantity":31,"st_dist_01":"Qv2dUgMNV5qt3wBz26hetRkL","st_dist_02":"t7Dc3WuFnijCaVgbMkcLEivO","st_dist_03":"woQP3TUt9hmhSwEkvf2TTHvq","st_dist_04":"agDuo3VQ00TWMVqdvHUfhwtE","st_dist_05":"98StYMSavoua6uZdFOIB18gj","st_dist_06":"RjZCjxSwzE4lHfqD6n5F2QUb","st_dist_07":"Rm4gm4q83SF02Ql8MwRg2d9C","st_dist_08":"HJX6i3erMESPkEVx71KETx9R","st_dist_09":"KqMAj3Vx0NA5gUgEnEyD75f5","st_dist_10":"pi54ZyHvGYdFXpVBeXHXRFij","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iDERGIidQ8mJUa4JHPDYh4SOTOoui3epO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":662,"st_w_id":1,"st_quantity":66,"st_dist_01":"8bm0sxdnuQf2JG2jZXembJ1d","st_dist_02":"tYu1Gl1B5REWtAdvM1ws9hVF","st_dist_03":"9W7bhL86MVn0Ysoqi5dj6WDk","st_dist_04":"Ot6gLhIYJaq2rpV7e6r8MjZY","st_dist_05":"iXusVje84wJBn7UUhQIwVlKk","st_dist_06":"uS8xPZp0dZotTYKoZIrDF5Uq","st_dist_07":"nsxvuAH1ZvdfgCSQp1xDrS5p","st_dist_08":"CpN6Tl7IK4YmuqW7MfwuJT3u","st_dist_09":"AsSywJJNzMogsrKIBidOA17M","st_dist_10":"qySvID6JEZ25WZU3M9uobBAZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IGMHoDL3tNqOkOAPg1i0EZ4i6da9Gl1PJr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":663,"st_w_id":1,"st_quantity":75,"st_dist_01":"vGfzYWL18LSCXjmWGpWgKIOQ","st_dist_02":"RVXVtcjUpxuGDIl3ohtOoDxE","st_dist_03":"133GXdhYiTA7BuAWGKQR3bYY","st_dist_04":"5d7z39RwWGqDlMU8sXramL4T","st_dist_05":"OsC99J5KvsIXMIbv6fJ7mUVR","st_dist_06":"0ELkvliX3yKza8izMTwoLDLW","st_dist_07":"p61yaWAMqfuKngvbwbpAXVEn","st_dist_08":"nYS93sn4SYBpEWuVzsXP2pTm","st_dist_09":"zv430dNqWi2GtGcp4yMzU17c","st_dist_10":"00pAVdSgg52aZJ1bLhRNWmNn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TmMElESFnAxhoriginaluZb39CAQI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":664,"st_w_id":1,"st_quantity":66,"st_dist_01":"nKcJEz82Gz0WCyNGWYrYvZxW","st_dist_02":"X8JruPyyJeCX474e66hGc13A","st_dist_03":"5eEAkGoOVtPSU7ASt6p2BzlB","st_dist_04":"tneSDN8A8Nt0xfsa4b4oQYmX","st_dist_05":"c3Bz9R1TWcgNP766GqGHiG7u","st_dist_06":"k1W9ism3o0Va11eR9E3nIcKu","st_dist_07":"jHWh2YmhG9ZobBuZkVmSSDp0","st_dist_08":"pBCvQaZfVYjytpdVMQr8t59x","st_dist_09":"tELijzvK2LLsanM3BY0PBMHm","st_dist_10":"9a45SNHf54EcZjlKU5GiDFL6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6RSKWmkEfe3tM2bVm81SaoI9YKPyWRgvTCqHefRDp0rc3VpsH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":665,"st_w_id":1,"st_quantity":32,"st_dist_01":"ZjRMmyRic1eTgMc5xMJ7sT3A","st_dist_02":"EkOYlFigfSMgTda66wYbv0XM","st_dist_03":"0oS9eDMHZijlbfVPtblsg31h","st_dist_04":"XqhTzmisdnOnDTK6lBBi5l4E","st_dist_05":"XkJXQtFdwhqzxfEYtNXdhyKe","st_dist_06":"1VHpRwQhlHkg5sadrxubknJ2","st_dist_07":"Aallo0QgyegfhhJb89b5G2To","st_dist_08":"RwBDUkqbC1yDvLaNWddjCOgj","st_dist_09":"2KzMGwcAY6r6s59evjJuZpVq","st_dist_10":"dtFB833LF4k5C5LttyxIeZRE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3Cv56H90EjOhplBxh1A1S9z6JqtT2Da"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":666,"st_w_id":1,"st_quantity":42,"st_dist_01":"HTlOF3tbyl9PUWlMXKsdimyj","st_dist_02":"qCYvFMiUIEZdF6MD3f3VAhT6","st_dist_03":"61jTsbMhCjkK36XGwGByA4V3","st_dist_04":"dOHJtkOXQnEawKCv7RPTMZZI","st_dist_05":"RuVSUQDNk9OIx6swEbM05W7O","st_dist_06":"Rmpk9i6oC6hABuwerMBhNOUP","st_dist_07":"pTymaZF6og3MZXxgT3UKQ7xD","st_dist_08":"GJ3EAOnf11IQwzrNpMxNYyYH","st_dist_09":"u8PJOHcf12CtiYulYLlFxrSP","st_dist_10":"hWIILg8wenFhlQxcAckryZF5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mxcPcFkWhxt30dJhf7B533M7gl0TKvHsX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":667,"st_w_id":1,"st_quantity":14,"st_dist_01":"HmyvneZZvDoRNveRzz34EPlD","st_dist_02":"zxf8Ey30uEvRfteGsJzKzPYr","st_dist_03":"09diDaLr9ikaqx94XHfWL7zy","st_dist_04":"6pmFhxKxF8fsklgNpMhBqjjm","st_dist_05":"XhjdmH9iEOyLvQPIkFG6j3ln","st_dist_06":"XMXYtKskVaLFc6DG9iEOrI6C","st_dist_07":"c7QuNP4OVNMTqyxTZ3TS2kOY","st_dist_08":"oiOViwN70TKHUJ3OmbejZlLs","st_dist_09":"UZdQXAcfuPudUjU1yNF62GdM","st_dist_10":"FU2y7y1PaYXNd87KXKJWVyIY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tXs5HngjFQZoHTAtNYXHv8JzzjKg7n"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":668,"st_w_id":1,"st_quantity":53,"st_dist_01":"QHHAdKet1qUiOlIMj9h5DhXO","st_dist_02":"spIMlTifAeq2CEwv9007Tewr","st_dist_03":"0Bx9KNoTePEOtWnOrTCs5y0d","st_dist_04":"XmrXUuo6JlepzGjbw3XR3pdP","st_dist_05":"d49s8qgh9ck4jAEq8GNnvl0l","st_dist_06":"1jfIXAzoOnOjk1bf87PWpomj","st_dist_07":"tr87FMxge1kxyWZEn8WQt506","st_dist_08":"zDtsMXBeaFMDhtOY2qWSrSU5","st_dist_09":"uw8eD6fEXtBI6UYw7Ewuylm4","st_dist_10":"wa8JsVz1bG3O8lT4FOgl6JuM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HOf6Sd05ixaNGpEwlH7b4oMM2XJvoboSF0OiMCH584vcB4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":669,"st_w_id":1,"st_quantity":67,"st_dist_01":"pKqpINBsmqXRZ2JeIhthMuIO","st_dist_02":"JmWAzFh94pcH6IlWBQdpE14W","st_dist_03":"HhatdsDmGFeFDyKJUtwaCMtE","st_dist_04":"BjKaRLO39BK5bejUH4oPbcLd","st_dist_05":"5QYTJv0lvjtfUGoFnOiXtyUk","st_dist_06":"BNhVSxvAF7kGnyUANjRwLV5E","st_dist_07":"ruwnduFKflcAKekUnYIycfso","st_dist_08":"TsKIpFS9AgedUyOOj9rTFUXg","st_dist_09":"zQGghvUNj7BrCMNzQpwOZTix","st_dist_10":"PNFzfsaQFVoset1IvcnFtgdz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZG1LzjQPEtC5Vl4doNnUm0ZIJ2iXYTl4ArC91GSjTYZPjRk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":670,"st_w_id":1,"st_quantity":32,"st_dist_01":"ldlzzRuPqqKGXP2BxEAAVDuB","st_dist_02":"2AvKWyrTh8sE7JEtOGxAEdUt","st_dist_03":"awb15BBXTSzMXwUfsSy1UA6C","st_dist_04":"45QYZwemjOb75JFDdK9jXHyx","st_dist_05":"cPamKqR25Hm3ydI7QLozhJeF","st_dist_06":"Ol2bcL7dtFE75UvlArdq9utX","st_dist_07":"JdW2EwXrv9BVSacQ3XDleXpi","st_dist_08":"iF1WZPogRAX9spnGRbOmVwG4","st_dist_09":"e7fLKDJGRmoeJdzlSLabhJhj","st_dist_10":"V8bcW78ENiHmvSKFQfZkEECZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sKY1oGhkG884xwYOOacVkX0jtrFYKKEOO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":671,"st_w_id":1,"st_quantity":27,"st_dist_01":"xsgIPko4k7hGQSMhOf20ARzk","st_dist_02":"8cpf3dWaLMG6nxzCSPEWyTHB","st_dist_03":"wYIsfvOuoSfW6VyY656eObxT","st_dist_04":"yy6UkIptrWqG9YPHX6QssHpO","st_dist_05":"bTmlcBQILWwJaTVhT6OofWeF","st_dist_06":"cwBl5vgnLE4EUV89Kc3cnrFc","st_dist_07":"J3S1IgeyKMPuvvxv4l3ecL8F","st_dist_08":"R9B5jOh8oIiLN1kQ9o3OEhIs","st_dist_09":"F0NmxERTkt9nC74rcobeGrI9","st_dist_10":"AeuUrsKxpnX628U3vwy0ddQO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"prqsYr4PVPukF8MSSEV1mgFhaNAN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":672,"st_w_id":1,"st_quantity":58,"st_dist_01":"HlG8ZnW5mgNUmOBH1hHxdB3a","st_dist_02":"nFX2KZM1gWTMolxIla522nir","st_dist_03":"BiOeuSq0bXw3l7OuYGOZK2XY","st_dist_04":"A2VGjH5s4XV9rF9NTCB6TI2d","st_dist_05":"GUzfdTZJIkXFuoPQksLGk5rW","st_dist_06":"G2wSMKldKic5LyXCUBaTYh8T","st_dist_07":"C3Essx54ZYU7n52kz8Jx6VfD","st_dist_08":"CTrwZgEcwoG0EIBUNITmExIc","st_dist_09":"kfQVOn3OvZNPXoq5zzP8UoZg","st_dist_10":"BjbixM5ol4P5xWSGykaDByMj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"86mbuwiE4sS06IkfinjtCCIZSR3Pz9wTk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":673,"st_w_id":1,"st_quantity":81,"st_dist_01":"Lbw3oykOT826ksc95gIO7YDT","st_dist_02":"Agw2HPKclXwgubZkKqfqu7ue","st_dist_03":"GiFBc51xnfr02d4WGdVHEkzr","st_dist_04":"5fXNK3yzMDc08610sVIOcmb4","st_dist_05":"QXBPZmbnGDMBNAWJPLOvHzib","st_dist_06":"jBpoHtfXFzd86pHqAPSmaJ9V","st_dist_07":"1KqK3VlFjoKtJx6McAnbArZ9","st_dist_08":"Qsbwb18uFZEhRgGffTSWaRdJ","st_dist_09":"KGOrGb8pTkjLVQtUnLMUX6Wr","st_dist_10":"nV4oQ0i89rxFb08LduF4pxZv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YysXRTRyaDC9sASbSsH1zEL9HdnDIOOjUkC2o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":674,"st_w_id":1,"st_quantity":94,"st_dist_01":"Aqr13cD8j5KNxkp0mj1FtlCF","st_dist_02":"N0ACE9EPUFSvgZVMtkntTclN","st_dist_03":"dbqBNiCWL7yyGxOS0Sdjrnpd","st_dist_04":"o18XVPg4hwLfE6v37wUmw4Qj","st_dist_05":"B1SuYuLDUaydODpuWkNgNGJl","st_dist_06":"Ai2lM7uQv3BFCvBSexU5WjGK","st_dist_07":"Ac1pUFd7IK9mjTyZbg5zgorB","st_dist_08":"rIuukVHu8R4BB25vvVW7LDBh","st_dist_09":"axzoXWNrhajn9iTg4tjKDQ06","st_dist_10":"mdhZg4wD8MvlrRPKEDi9g91m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7y4N4K8InzP6WgDdmSeJDwdBojr1ehVu4bj5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":675,"st_w_id":1,"st_quantity":39,"st_dist_01":"vAcTQ6yGL9OiVVwSYKYo7ZEw","st_dist_02":"39dnKAbnlmCkIK9zpBnX6Rom","st_dist_03":"QOqLiBXqeeRif2mninYvyI4f","st_dist_04":"W5rWVLWzL8M9nIYLlQK6rrSr","st_dist_05":"Dj1Lx5ReXQYx2gtB9QTKFlWL","st_dist_06":"yYbBJIe5kR5RsdrRSLODDpP5","st_dist_07":"EebnsHnc9jE4YxdbASwqbxEL","st_dist_08":"okzTs68R5djKj20MTl47c66Q","st_dist_09":"bZmg5hCTw32sFEHgqLOSKqlY","st_dist_10":"LCuqpCHa6fhO7qfuLH3rj6vI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"52BzUt2t7originalKJR2XVBYBwawgffx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":676,"st_w_id":1,"st_quantity":17,"st_dist_01":"lqcYtSggSPPz18G8ICOtE7c6","st_dist_02":"izod163kNpCBVEaXM9cqgSrl","st_dist_03":"5D9fjHPnROTIrH04lKBHXbuE","st_dist_04":"N2MEfrVUXr4w3JFW9BVH60MO","st_dist_05":"ul3y0LOLq60anDvHcB87K0nM","st_dist_06":"VjKyya36iCp6b8sU3AkfuFYs","st_dist_07":"RO2K3rq8G0gleU2ZjTS2rsnX","st_dist_08":"ys37MVYbSjlz8aa3fPmYXCMp","st_dist_09":"70xFwQeLkUKxbKXzCmaFL1Pg","st_dist_10":"K5xQZjPdYBlnO5VkFDXutU6v","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GIhD22zFFHcPlieIXb5ZitOmfpzmOGMlhjIA8i4Z351Q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":677,"st_w_id":1,"st_quantity":91,"st_dist_01":"27dp7sR6RmEWHyU1ZFLV7JDz","st_dist_02":"hjxyJ6rCLo0Enwqgtn7muzeK","st_dist_03":"rgDgglY0pnqIIlSGHLaW8Yko","st_dist_04":"3SRIYXqzMc4sJ0fMeYuYBGCV","st_dist_05":"gBXJW6FLAOJGbwZ7Fev2aKmi","st_dist_06":"vfMTtI9KaEkSjI1g33aJyK51","st_dist_07":"zu73xERt0Y6Q0PlOYdCKOcsA","st_dist_08":"QZ4M21xSHvSxuiM2yL0Topzu","st_dist_09":"WHQRIs1cBlRtMDdSeuRM2Kxk","st_dist_10":"s5wCB8AQfleIE1ISbjkKRzQ7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"87c5jY5yeE3qH5B8MbDGvidVIKYfiEedaulAifxXR6vXCGUDPx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":678,"st_w_id":1,"st_quantity":38,"st_dist_01":"P45C2eWmXBMSisMj9Uy9jXvQ","st_dist_02":"gPwSaKmrjL6Bsp6IIo9bE9Kq","st_dist_03":"u2MifPNVen59J5JgDWR1OzRa","st_dist_04":"izbpAvwDCb7xPLVpFlHHQs6m","st_dist_05":"sODrLRiItTzIiweP2W4hD6gd","st_dist_06":"iTqOdYIXqCwNGD65YwWqf5HD","st_dist_07":"oCt5tqQUisXOfVUhJKKM6oxY","st_dist_08":"3Ue8eYghe9ZNF5ghJJszSYJd","st_dist_09":"V54JuClxeqonxVtRNIXmwk8Z","st_dist_10":"SO7KE8Zqpa5WDlu9rPE8UH7F","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lfYVXRDDegF4iOHYmfH68nEsAcVIi2M5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":679,"st_w_id":1,"st_quantity":84,"st_dist_01":"74xjbKeU32fbvQJU2xHlwqpx","st_dist_02":"DZIQCoTdqdCImbYYSeYKVIQA","st_dist_03":"GS0Q5PVWDtnlSkI3EnvBMCo6","st_dist_04":"w5fN1pna6Wittrh2USL7CbIk","st_dist_05":"GetrgA4wy9YrSMjv9NMdMwRH","st_dist_06":"31Vw2EvNjxiGBQ35O5JiemPA","st_dist_07":"oBIdwQVbdyZdsinKy3PslUYC","st_dist_08":"xCxz4GMrpZhYlLtv2q7I6vFe","st_dist_09":"GUWOPhyyd0PoxQzFmZNFu9SK","st_dist_10":"Jlv9qF7LjVT1UV3baRpzeQuI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"44CYGPhYganTwN27dlJmTshBzaDqKVg8bQCcXT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":680,"st_w_id":1,"st_quantity":39,"st_dist_01":"6H2oEkWka3ZAvB7OAiKK1wkk","st_dist_02":"wgWqoLZCedDanLFmT34pRBG1","st_dist_03":"fnrAvUvv4Is2MWnPWgVewsim","st_dist_04":"5lSmjhRlf4jXNf1TB9yrAIYw","st_dist_05":"hxrHxmoFgZyPtPHY14x86X3e","st_dist_06":"DyeMPv8qv5S9DlSQ79hrZZeG","st_dist_07":"AfHnIJULPR2xPGNG67voTSIe","st_dist_08":"5qVhfLRjoniZHAw36xpEoCwK","st_dist_09":"AFCyj1iIZAEV7zzKCYebPgbD","st_dist_10":"8cQ0X8BQZ9Qciiwi56QQLTcz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZjFP7IPpZUEIEPhfnc0xgRxrdBKwr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":681,"st_w_id":1,"st_quantity":53,"st_dist_01":"2GQYNOvRsAfBN8AEXm7ABaSv","st_dist_02":"ZjtnCdHnkhRTXB8WMT43ecxu","st_dist_03":"MD8a7kS80qXfn5Pcqp7dXE7p","st_dist_04":"K2xGfUVzI5pfWCnMVamPKnAY","st_dist_05":"5Xwd9Ht4o7bB0Rza1ZPTH6zS","st_dist_06":"6q57x5TtMB4G2oStrPaxOiWg","st_dist_07":"Ub5Wr7Y4Sb88WW5W4f3tCZj0","st_dist_08":"RVJ8aBMyy3XfADrJZLjUjkBL","st_dist_09":"fOkahcHcbEVpb6HTFsK84080","st_dist_10":"7ef4an2NyQ4l3hzEKLcsfFDg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NgbddNMgEu5fDt8M37uH9lNBP8hhFIBVCTDSJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":682,"st_w_id":1,"st_quantity":73,"st_dist_01":"FKSLMLP1JddXND3IflZ9uxud","st_dist_02":"Pm6jIf0eUehSQnNgPJG8chP6","st_dist_03":"gk1V4GEGqnKIcg14Skeg10JP","st_dist_04":"xcFnumj5T98XGtDvGCwv9frq","st_dist_05":"oEUL1xvVsEZE7XbfSfBkTsvJ","st_dist_06":"lOnSNiRGxjY4J5aqCFR3zqIq","st_dist_07":"07C18DeA0KXzLsZoGVSbjauB","st_dist_08":"XVNNJ1jAATBkPVSdjzTGTkMs","st_dist_09":"mr3hE7hCuUEnqGkgh90v4qwJ","st_dist_10":"1LBcTxStwB4GwITgYKI1WsRT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"39bZSkiLbqepiuKXaS2se9w8oW41OMeoYghu7PpGQuz0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":683,"st_w_id":1,"st_quantity":72,"st_dist_01":"kLiWRsw8oznjk8cba0riEGeU","st_dist_02":"h16Ywf33vrIZwvzt6eA8SjS3","st_dist_03":"JrImyeaARKEsfH1b5s3prRh9","st_dist_04":"SYZ1JuyTfcmlsS5ib9SLREld","st_dist_05":"YZakqNBb0izosWSx8gkoCG8P","st_dist_06":"ixoShnkMOWtpbBJ5SGe3B4WN","st_dist_07":"AYW3LI8KUK0LYMmo6grI0en4","st_dist_08":"EMO104pNGFdn8YB3Rkdt0VkS","st_dist_09":"cEfH0bTIQ0LiwRpyAWE0mtku","st_dist_10":"3WCZ9eFC0QSybENPAe1a7L1c","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lmkbsS6Tx2kI9zosNEgPK4zemGkLGJysDgALC7RV5Rtkz5Bo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":684,"st_w_id":1,"st_quantity":89,"st_dist_01":"jEUTTuLt6NbzF4G01q1ifJ1D","st_dist_02":"E9srqS6jB0uldqA89qYiIf7s","st_dist_03":"EETiFHZg3uUOIJ4ZvTUJ8Vsy","st_dist_04":"QIwQhNIEjisgPHh1ONG82yUo","st_dist_05":"7lV7Sv6TBjNmYWT03mf3EgfF","st_dist_06":"WsitkIygM72B9jL7jbU8Pbi9","st_dist_07":"41tzZXq4LUnvvQ2UOmk0eXGQ","st_dist_08":"9MvVwXCP3I0OOR4rqTIKDoYS","st_dist_09":"R8eqzAEZpWQVHwGesXEEUnJs","st_dist_10":"HkqB7mH0fzewGZMg6qtrwsuH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kPue3hsswgz7qwCBQ7LVPCiFzkb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":685,"st_w_id":1,"st_quantity":17,"st_dist_01":"3KsHxr6DB2XDxA97geVaZ1ln","st_dist_02":"jGoSOI51a9JdxrKV4SGyUnuC","st_dist_03":"DLNVCi5vh1jZPgEpcXe0zdvN","st_dist_04":"vIxChfqycsPxi4Sk9csFqCtL","st_dist_05":"CwYWdMQBuCWTTxYF90ApzAk6","st_dist_06":"ur4zU4gX8qF78ukdhmtpw9DN","st_dist_07":"8mqqEPMa6cuhLPALZCI8sfdk","st_dist_08":"4FwbKxVZxBO5iqpdjRvOp0xZ","st_dist_09":"7rBZ4rVtGL3HC2p5CNMI3wql","st_dist_10":"uJMfeFIMoJaawL0yfTWfYv7q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"40XSvFr2MN2LzYERkxl4uEgtEj4tITj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":686,"st_w_id":1,"st_quantity":39,"st_dist_01":"szAmMNiZywf9KCbyfUoOLbFG","st_dist_02":"nnRvEQvL6utjlY59u08kgVBh","st_dist_03":"KN5paCykH5kGcN9DTIQmoTm0","st_dist_04":"QcSEsw5Cy4Qu9Pl0KAjTsF6n","st_dist_05":"yWbWqtaULNuxuSE1EGAwMe42","st_dist_06":"67dHpTTLF1ASlUFu9jNmAVXu","st_dist_07":"vx8oE5JT9e7iaBe0II3QO0Rn","st_dist_08":"GSRCbp2oOGE5WDQq41FsLfHn","st_dist_09":"IBqmiNNv2qTpgL3vXBfjVza1","st_dist_10":"tdpM3Mch6RFJkF6AFykieBPa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xBwTDs4sfPfuf7siFicimZJecFYc2P9ffSVOgApvrPHOL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":687,"st_w_id":1,"st_quantity":29,"st_dist_01":"jUIjYLufZv0m6MBkgRR1MWtz","st_dist_02":"nv0A1VO5AJwpewdzrVp2Zpxo","st_dist_03":"8ehrd53wwRffZKeir1AK3U89","st_dist_04":"cZnQDsUyDncENlW5fNP0qFDu","st_dist_05":"yKnTg5kUtFr4KL1r8PRJm5b3","st_dist_06":"0gYYmIyWoN5wWZEml5A6MPjj","st_dist_07":"SF94SMRcfTAzsiyHu4BShkV0","st_dist_08":"HLsBNOligbiSR7ss0daE6psd","st_dist_09":"fja9neLjcMURqJqy0tcwr5dB","st_dist_10":"ZhjCVDklZLUyMkz3f0uuoEwu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Q1pvm6aeAt2IFHEocTAKmyjRUuoegSCCbFPw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":688,"st_w_id":1,"st_quantity":40,"st_dist_01":"JBsoQ4ekQNEIb2yE1uHDPaD9","st_dist_02":"20DqWBuuevcWLvVwoz1aqPjF","st_dist_03":"YwyqiiTJtL4xUD68rmNNGGVc","st_dist_04":"JluonGCKq9gfOcffIGfkzkRk","st_dist_05":"BbagTTiVCoB7AY96C4nro9eL","st_dist_06":"mwrlninDUb5lzeef0u3P99w5","st_dist_07":"dsNkVOsBUsa9VhVpVYiXpEiK","st_dist_08":"XqxbG1xkBgQmiFZFwHpyw782","st_dist_09":"lSi6c0ldptDUGb1Lw5nFIjVR","st_dist_10":"EM2Bixd58WyorJTepmzphVb2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6EatW08bXwgbjaLZq1yW2mF3TgD6dwz8ESN6qDP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":689,"st_w_id":1,"st_quantity":35,"st_dist_01":"ILAmRy6G7RsURAfjjqf8eK98","st_dist_02":"CyYjZ0n0a55JpsWPOOCLW5kj","st_dist_03":"C78nPF41rdXlQHBCo3ZlxdIa","st_dist_04":"Cxial7QpNFbQyY8qOhPmhhYn","st_dist_05":"2JwzHB2ftmSfpOo5cDywrIzx","st_dist_06":"NrTlYPpwsH7fxuKAQqjCeSC8","st_dist_07":"VJnuEcrvoa8nL6HQau6w0Gag","st_dist_08":"CT2593XnbexyEZ64bmHgdwVg","st_dist_09":"cfRBnntPdnPEhMnWC5vxSrjb","st_dist_10":"EfOIUQHktk2ZYdsYu6DBKtDj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wtgM6XShA4Gowckuwdj7vi9bZooshigCfBfizIo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":690,"st_w_id":1,"st_quantity":55,"st_dist_01":"uxfY8Na06sRHzHd0y8oxHNIz","st_dist_02":"hxEWrlCSVaP3ODnvMCljK9uo","st_dist_03":"ol1jjHkXPQ9DoHLa0fw1gR71","st_dist_04":"W8xCex62zBCBeZWGBooj28VS","st_dist_05":"XRKPDYjOvoaiqmZ0GLIFkROZ","st_dist_06":"pJoAQeh111btmWRz3LuHjXqa","st_dist_07":"7feFeWIn1ldsvbfL9qcShHiX","st_dist_08":"Fc92ILXFGxDgHvSLMHwHYawx","st_dist_09":"dozsD6d2sNeIAtVsYdjeMacR","st_dist_10":"VJ9ANRY33lOqWwxPpaUdFg21","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2FCUC0dJrrXWsLEGpt7FUVBR8MA37YeGTn47gSffkDY5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":691,"st_w_id":1,"st_quantity":32,"st_dist_01":"Wu6LBNjqJR9cyy60AFS8szbh","st_dist_02":"X2qqKMngTsMIXczU42qBv5Fh","st_dist_03":"i8CW6kS8ZQbL6n4joneESC6b","st_dist_04":"XgkIqovvxv4Ib54We2JLEQA4","st_dist_05":"gQ7lrdOn3mB9uSp0KAXlzwMW","st_dist_06":"AptcNHEDLrkarsOll9z6jTTj","st_dist_07":"q0IZI2lpWnFsK7eKUOTP4dCO","st_dist_08":"7FPuUkkjxiRT7kxGelCNSllg","st_dist_09":"Rs5iX5DUymrX4853ccE1TfFY","st_dist_10":"diaRuxyYQL0LSguiv0eEql9v","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"k7mlVQKbUi2Zl4NgtUHVLOoiN847"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":692,"st_w_id":1,"st_quantity":72,"st_dist_01":"AehiIHFIlz7GtfXZptVhtU3f","st_dist_02":"xqig5Mbb0PoyENlRDPAYS7bt","st_dist_03":"enz6oUKzQDnr4sivk8iMr9nd","st_dist_04":"VkMT0OhvjofdfB0njI4qNhJG","st_dist_05":"M3nbNpFyrCYAsB7C5EE0F120","st_dist_06":"1WSOBK4Yrs2wvINd3rCHkVzr","st_dist_07":"yEn39CbzHca84REJznqMtCHP","st_dist_08":"0jYPb4oCcfu3OxGgqSmUNLYW","st_dist_09":"81gkWGTp4hprdX08g55aWv8t","st_dist_10":"PtAEvZJIJ6InbhxC9f5UsQDs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TccnFh1G5Os13Ga6Hn1sytVIYiIAZd6GT5Qzwbh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":693,"st_w_id":1,"st_quantity":75,"st_dist_01":"PIzmsE5REKWn42fY8B9BYr7k","st_dist_02":"aefEVpsvz1vlxIPNRwlpwP4t","st_dist_03":"uh87b2YKl82BzUcMpawLcWfm","st_dist_04":"DyiryavmndtdcNxk8Zb6oDXK","st_dist_05":"N3gdPaDpochkeGlON96fvwPp","st_dist_06":"VAXhd4BIToupTwdxqRNfo79U","st_dist_07":"9CjfCT7UFY4evURNDauwFHd2","st_dist_08":"zwJWYb7ESYZiZ8NoviKSssUv","st_dist_09":"1J2N1YVOmRrSawGXMAB73YSa","st_dist_10":"K4oqbeAnTfsU5EN0qdQmUSDA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"88MEll0p2pLgKZ32ovBR34ZoAlP0xuByG0qmLZHDiTXrrAQVi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":694,"st_w_id":1,"st_quantity":21,"st_dist_01":"01MPKnZxEcl0DFqo49KO6zvm","st_dist_02":"OnftUz25fkJAg1PzJOv02yCp","st_dist_03":"1SEsmwwq4e2PRzjwajy1tT1B","st_dist_04":"pmENLZ4qSjtvlD0skyIYSdKH","st_dist_05":"YIRNyPANzY09d3YWmBseP7UO","st_dist_06":"IjwnqFuEHjUGFo3KmBfuIk8z","st_dist_07":"DuP1u8izIR9CAM4t7ubNQkO4","st_dist_08":"V7677R6rGt5c6fhYUxF0axQK","st_dist_09":"q7UG17OXn3OqA7UfdDoZ1uhC","st_dist_10":"9IynRnrH17rAmPUVLqxxOP7p","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FJhiD6uR5aZAAjFgkGiA1fz8keqekQapsdtFQI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":695,"st_w_id":1,"st_quantity":72,"st_dist_01":"AUlzZXJ5Hh3AZ5I9fBBxMW1F","st_dist_02":"wW9GkNlnesKDX1H5kJCZsiq4","st_dist_03":"lyELeoU5Hxs0iGpAqEx4LX1u","st_dist_04":"3FTBW5oglHeC45t0t8KpSr4p","st_dist_05":"bFISnjtFs5rt0UqNDs7xvINC","st_dist_06":"aOn2EtKVNwpMXx2eyo95eDnw","st_dist_07":"Ngfi5TMcOuw6f39aVNkL4pjG","st_dist_08":"wkrznB7GkR1oFS1yIoWNM6a2","st_dist_09":"5EjzPn37j3TVNfypBYPA5hot","st_dist_10":"Ja3Z1OfQX8FsGBEktErcRNO6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KQ1k7aF2MVL6ylT9EhA5iRHAt7RPAHsXyFQY14f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":696,"st_w_id":1,"st_quantity":58,"st_dist_01":"0E9fyafjXFTqAMKrqy3twVuF","st_dist_02":"YdRgIAYD3uhCylGeQciicK0s","st_dist_03":"VlGfs3kir6FdWAmXGgnc1Zhw","st_dist_04":"FfmG6n83dl6ddWMCtZodcYB6","st_dist_05":"M9g5ZXVHgznx2rpPZWdd4s33","st_dist_06":"lvNbJZ8OJDkUC8srpDtPIF1j","st_dist_07":"F1rGGpeoJSCVk0HeXWQZmAR0","st_dist_08":"u1ipEsJone3JQ20kqveLhrIc","st_dist_09":"3ZOKNFooYbs0CZvlnE7t2ZBK","st_dist_10":"FcAUh3G6s1Dl8DvAlLTNDlmj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jBPovPmiKUtghA7UESmI4odj3qxj0gmkTX2v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":697,"st_w_id":1,"st_quantity":84,"st_dist_01":"rEFxTpTZ86ngi7twC0Hvkt7x","st_dist_02":"fttgRPKk0zuDdrVC9OYVlF4H","st_dist_03":"U4aEOz8V7n9bc0jsqGu6Ps36","st_dist_04":"xXg6NEyPVz0OU2PL28CGoPZ3","st_dist_05":"YTqvKlCqY51w0d65caHdcS47","st_dist_06":"Hqc5I6QW2XwqF0YshOL6DOxG","st_dist_07":"AGNmePPwwUIt0gUKOv3SDN0W","st_dist_08":"05TBAk1xYEWPdMMaXoUM0Re9","st_dist_09":"y3HaaBTBhKK0BvQcXiZY2dvE","st_dist_10":"8fERiADkx1v2tPwURouyZL5s","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XsSxFjL6NQqFrZMPgIrumglzoPZ1PEAilsgmxcvUDnxXy2pgt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":698,"st_w_id":1,"st_quantity":32,"st_dist_01":"58Q8PErmRcflCome1k1Dc50x","st_dist_02":"ds3H6h7AwNQs7jFCUc9U1H2Q","st_dist_03":"k5xue8hSvza51fnvNm9GJzsn","st_dist_04":"jTUts7WoGXzxKlMjDy5svTDu","st_dist_05":"FiZ3KM4CH1xmCU9X12QYtNzG","st_dist_06":"WLkWQwSKeJwaIeu28jdl2qKc","st_dist_07":"NJAGH4OP7B2lvrOf1VszNQRc","st_dist_08":"A0Yp66FvITV1MD7oKItxK8ka","st_dist_09":"aQL9PEw4pmFQgQJ11U1VVln7","st_dist_10":"poCnZnqCp1KkUB4nz83HS8EU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tjOz0ENoPN49x6originaloeWyLlLrOhH0FhVxvQvrYD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":699,"st_w_id":1,"st_quantity":38,"st_dist_01":"5NxDgRdVsBJWKt3Cs0kW4gpe","st_dist_02":"5fOddOKP7D5b6QpUuOxmPYr9","st_dist_03":"j2ebXcRzqMmfhsaPeY308xvg","st_dist_04":"f0GXetzssOdTXam5rUaHI73K","st_dist_05":"h24St67lbSrUARpGABRObbTC","st_dist_06":"QSBQF2hu9JQSoZ0tqXZhGEBr","st_dist_07":"zARXmz89feIzqZeNJt3QOFdz","st_dist_08":"5AxcSKLvQyu0eYUqLmaKxNY6","st_dist_09":"h7nhHx6ZRd5hKYv2ViIyy2zO","st_dist_10":"eoqeaBIAeSHSpG8dFbOHZgAp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VjvnzWV8s2i6ipEZ1rlogDIlNX7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":700,"st_w_id":1,"st_quantity":24,"st_dist_01":"iOfkkAtTPcnTjT47GRLBrPLj","st_dist_02":"SmaolPNJPrJj51FtnhHlyuho","st_dist_03":"UIWcuGxqowBnWtxLjAFLuNbv","st_dist_04":"6xMfh0gF5KIdzUDyzKa24gZj","st_dist_05":"PBn28IDwQ8KmDTVwqq1bCct5","st_dist_06":"jEtedcJW9mDhRbapX2HeUgVr","st_dist_07":"4alremNxxAO3dsINPazttbK3","st_dist_08":"fjOSZZYDk1ndXmojlI2uHEW7","st_dist_09":"AaLKiFBq4MURVa7Cr6UA1N6d","st_dist_10":"sVIRdtPLGAqanRz2nwviriMc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"av1NbS3PYDQWINiiKC7GQDDRZ7nY7tMTplCBgDfZEc5Hub"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":701,"st_w_id":1,"st_quantity":60,"st_dist_01":"3YhmTGBgOaD81080IHHH9Nlm","st_dist_02":"6WccGTnagVRHcw5oKIpvsZLS","st_dist_03":"tkDDOR73KxhTzO2biT1bwwg2","st_dist_04":"fLtndG0k23bIiRnMGD3j4SZb","st_dist_05":"RkFBxGRrYzSSpNU0wh7OakUw","st_dist_06":"46TtalKCFVD2ZWgGIrS9KoQe","st_dist_07":"9qnmRapoBbXA41odLJsMwaZs","st_dist_08":"QiI1AKqRv3TI7wDjYD15LLyw","st_dist_09":"Ac7S1vGMctsT2GqGYOBaCKjZ","st_dist_10":"so8tYfZKJ6dRqPmTnWswEOWk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nDICq9zWa9yUsgvbKRcU4ROjoWDvJazcljrbZR6t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":702,"st_w_id":1,"st_quantity":68,"st_dist_01":"ULOUZK8hqYGvrsUI09lVe5R0","st_dist_02":"QB5s6qCbddlKGG8A1q1687GQ","st_dist_03":"cfoWUDRt94IXK6Ke9f8dfzEA","st_dist_04":"iRmdoCDGP6feHSkxetM46Pof","st_dist_05":"ztRXvkFx0bbhHKARRP3BgGRD","st_dist_06":"TG824YIMDwuBR3ZHDpcU9XZ5","st_dist_07":"lhFbrXhH3MwKQxcwX36JPrJy","st_dist_08":"2Ed59NtiLulg2JxQrBt4iOqB","st_dist_09":"NpqJWZdmwl1pqgNUSbur7TUq","st_dist_10":"yIzqZbHoyccOTuWjgsIXZyIG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7R12dj7ehY6736ERiK4ZNMuRBrWgzTHaQ8uVd0Wrq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":703,"st_w_id":1,"st_quantity":27,"st_dist_01":"Z6zgBkaHbOdNy08aQiKL4nxe","st_dist_02":"m4ch15Hza3zMToD41K2HR3xo","st_dist_03":"5eFBf1pffO6CX8VR78UZDJev","st_dist_04":"gT9GGyjBHb2ztPpwW8VbFQMa","st_dist_05":"MXbkCEADoITkObR7mhZl5zP7","st_dist_06":"McTYvSW1I0uRikL4zNmKw19Y","st_dist_07":"M7bLHpHFDe6pa1wGeYpfQaEA","st_dist_08":"GpMLgQSSkMbIjsc7EO4gEcNT","st_dist_09":"So4zhYC2zXCeTDrncCGyE0Yr","st_dist_10":"JoKi4Py3sDZMsEfJlT84xZfW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3ovQA1rdPSsctlwKsOzL3NqJgFhZcJyIvnS5ql9CTkVLXzc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":704,"st_w_id":1,"st_quantity":86,"st_dist_01":"UnsnkRQLq7XouMzzydmr68F9","st_dist_02":"D9seCJiCUl4yjDP4jXQmN8PJ","st_dist_03":"IJugXnrp4t1m695u1PGLKL3N","st_dist_04":"s6MKvQWge7pta05Md2wcW7kp","st_dist_05":"S5TNBxpPx33iSTOkfgMK5h4a","st_dist_06":"pwh2rTvWOVxyVYiX71YcSlWH","st_dist_07":"E8dNFbVF7WP2KRxb33YFOuzm","st_dist_08":"5svyzIkwH8Sr69AY1X6ivml8","st_dist_09":"p4ArHEifKURmBFjgG9pfKny5","st_dist_10":"WUfyOYyGO4735bNCF08aTZ8F","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2kJviu4LtpK838rGrpXC0NwZFtji9lMObFVkYkMyGq4MVY3sAS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":705,"st_w_id":1,"st_quantity":18,"st_dist_01":"icnuY4hCTtOlOOlyxON0UeYJ","st_dist_02":"GfuLU15ug9OckOTuzR9rJ0xu","st_dist_03":"glY6Skv3IH8RDjTHvc9o0iA4","st_dist_04":"G3v0U8sDBVeycmvm4xs106pj","st_dist_05":"kesqEYOlYdZL8FyQqZnfbrNI","st_dist_06":"UZdpCI2RqkwDhz9n6ELfdJvy","st_dist_07":"PbtTaksHKQyeWBzxiMOhtKhd","st_dist_08":"mysQgEYNqVVt0MJ4KrElTb4Z","st_dist_09":"iO50tXyTMyllWCF1BP2ZdWwP","st_dist_10":"GkeYg91Oz1S47869eiohFoR1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PnLwl6YeASjxElkO0JLLZ4geIYsgiQfywV1XOH0ZaN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":706,"st_w_id":1,"st_quantity":87,"st_dist_01":"LSBFeYyE0G9rsHVeTOsMDfno","st_dist_02":"z2uKYESP1T3GMO4QEjhTOwBj","st_dist_03":"n2JixbVHurrZoPFJyS00SWd8","st_dist_04":"Nq8LSoZL9LA3S1uoU0tlFavM","st_dist_05":"4iYGWtCgylXjy0zI9MGsjkA1","st_dist_06":"cF65e1eVy9ShxLaGGTtYmzKe","st_dist_07":"mWffTnheTKRJQXlUXT7ywWRk","st_dist_08":"rYm4N26YYwh56dJsF1GJub8x","st_dist_09":"Lt3sw3rgQiGu1Kt9jpjXl2nf","st_dist_10":"CPxIppfFw85DF6Ascts36PIw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dlF8XQOEFMOKiXmBYDT714gGulw3originalF5WiJ8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":707,"st_w_id":1,"st_quantity":55,"st_dist_01":"9yZWYkypjKArMw9iDZZgifMt","st_dist_02":"d3yDjQGWt543VW9ibImMhXxY","st_dist_03":"YcQ9eaYSzQXfuVKbZ4DL86Cf","st_dist_04":"imxnhiGROuXsfp5mmLsmbAHT","st_dist_05":"KCPNNXiJMfFR8LK9XoYhVrIq","st_dist_06":"vHqGIMGvrXXk6FJ94IZPr6pc","st_dist_07":"0V6A6nrOueEwIaeSm1hBmDZ4","st_dist_08":"9qO27tyh1DPBdcsYKzZ5tbbg","st_dist_09":"cRqSzu3zmQKJvWU0n36uONiV","st_dist_10":"WAQ2lf2BnXYgo0OTdsOK2ijV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JYd9Ae8TVi3gS5Ntp8OnLjlLqnnPYqVOtuzTgI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":708,"st_w_id":1,"st_quantity":47,"st_dist_01":"7SWdhvVOwPo6bsb4nhjoxNTK","st_dist_02":"wbWkZCSng0MEkiYGASOiSL6W","st_dist_03":"T9CIdLJ6fe3IcFWV1qJyaBe5","st_dist_04":"vkhCFHqpqd4UVYSxyFa0EGlr","st_dist_05":"SXNCalaW8HDO5CHeH1JBM1r4","st_dist_06":"AvV40wXsAoijMdVy2qZIFs8i","st_dist_07":"CY1TFH5vPiaWvXILDyQoz8Yt","st_dist_08":"wW7zz8dUBMkuDOYiI4ktSLUM","st_dist_09":"sO7Ir7qsXLJA0jHKNLgC5yNG","st_dist_10":"vHZnEDh8l9P33wRTd1gzzgIU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UHmPkIyV8wcBDoe8swkkWPl1mE1EDzlVcMJgMic36"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":709,"st_w_id":1,"st_quantity":57,"st_dist_01":"KOwRloC9r3D5h6SgUMYugCky","st_dist_02":"Gyw6m3P7EGGW1egIU1QSbr9L","st_dist_03":"ulvpTWP8JsWf2zJlvlTLbbCC","st_dist_04":"gJi43DIpJqQzlmSek01ohDLa","st_dist_05":"8MOMv9AE087mGJ4YQA9K6lND","st_dist_06":"q80Z0dMhepVCnPhKniIhQbgO","st_dist_07":"JHtp6aASy4kI2bLvlBpHGVWp","st_dist_08":"HFo7VAGfeySglkHVKz6o8uq0","st_dist_09":"xugCWDYuWrulxrcU04fzXFbr","st_dist_10":"k5TTRVp4p28cMo78mXb73zIW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qpcK16lXElBuBD1Fss6vroJ1Wg5HkUwupQ6C052D2Sqtpuq1X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":710,"st_w_id":1,"st_quantity":47,"st_dist_01":"lYV3qyzjdIVOf9sv2ZP0G1rR","st_dist_02":"bfpakrlMroXkbZGobeFELUk5","st_dist_03":"SE5SutoqkrRsoqWRFAnMmexa","st_dist_04":"iAPUkD6FAgj1UYPrbiqbpd1k","st_dist_05":"O1mlXk0J7FEGXOGDeIsj2gAB","st_dist_06":"mpW4Imrujh8I9uGbqIAilsBG","st_dist_07":"W602HCxTxQZaFSXPohVK72qV","st_dist_08":"XXwo3UificdOGPElXfMDH9Vd","st_dist_09":"9vuyNCyuj1DIY3o1vn37oTLD","st_dist_10":"tHK7YmedoM221gwAGldXGJ4j","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vEhJdUrJniVSgfgYmMeAqkfN3vZroNYBR9cjQVUZnJT46"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":711,"st_w_id":1,"st_quantity":78,"st_dist_01":"9U9iODGRM40nq89sonRmXMsX","st_dist_02":"P4Aa0fxhmHfpxPz0IcGerZEp","st_dist_03":"SzxugMz7ahV6mCLvxiL3AYqc","st_dist_04":"XYGbctYhRe19u4qG6BplpLgb","st_dist_05":"87JXzyGw1cGpY6SFYP3IUUAL","st_dist_06":"AvMBhRtpWugRLoMnqEtvZpiO","st_dist_07":"sR2kwLJnPBzMsVnXL4ys2LHm","st_dist_08":"2zGWVmQYu0BxaZbvcntmQCBU","st_dist_09":"wVVpwmm8un8QJKxXSA8oeFd3","st_dist_10":"RhIRCig4iJ3IMhK4mSEQ4dO8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1pbOawbW1tuPxq4SWqHWMiTODWfFgS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":712,"st_w_id":1,"st_quantity":57,"st_dist_01":"nHYl6qV7pha4yEU7OeqXv8lE","st_dist_02":"icakBDWzA4I0OsDWvP6On3Mt","st_dist_03":"CkwX67pkA4md20dIf2bEmTkM","st_dist_04":"hxTawVryr7TEYBSXiVLBSOja","st_dist_05":"BnfDZqpvColFCUKnWbhjYRh1","st_dist_06":"KOa9ZuklJAGuKX7QsHWwISqI","st_dist_07":"bWnUnLW2O8AL7fqP4ytm4tzq","st_dist_08":"bXENpjRKq779ntKwoSeDqYPG","st_dist_09":"RyAXKwtRze37SIurgC1dM4yb","st_dist_10":"OPD1Ee8LScoH3Klxc8C2zGIJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Qvy7BQoriginalbY0rTWnEghd3YQiRIR2CCIe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":713,"st_w_id":1,"st_quantity":39,"st_dist_01":"ATECQxvXVepp0KzNHgspD6tR","st_dist_02":"NJj63pnCTnXq78d1rVkAnaPq","st_dist_03":"f09yPPhHk290eJKd6JI4zMVN","st_dist_04":"FE7JRoXmbXsxkCKbWI7MyY4u","st_dist_05":"lI5iyZgDt62O6Mgg6fN0WCR1","st_dist_06":"vPCpV5B7VsgEr8xTMQRClAsZ","st_dist_07":"ZzpFXXh1Np8yZctN5Oni4Q84","st_dist_08":"1f0bVSyyMTG0pkvmrFVRGfCJ","st_dist_09":"wONRR9inchK0vXfyXZFTDK2C","st_dist_10":"6NqiJF4ffvSqtNdQSikb0fmt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eqlVqesWJDT1N4BLoOPGfV6KoriginalKuitRVimv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":714,"st_w_id":1,"st_quantity":75,"st_dist_01":"CSzRb5z80UznIS3FiVtElwo0","st_dist_02":"z8qYEa0tEgnzwlCF8B0FnfqH","st_dist_03":"4eUQ5boDvBqRhGwGBvvM4iq3","st_dist_04":"hCO993TNkwT4F9QZUxIdokMC","st_dist_05":"rI30RkCr46jhayTewzmOPeQ6","st_dist_06":"wnzY9zpW4G2ho55fVf600WYy","st_dist_07":"VIanga24VoZk6zIMYRn4UdSO","st_dist_08":"BlNXscZprk6IXiBcDHxDXNNF","st_dist_09":"Elsivp27ZNUalN3d7q3uE0G9","st_dist_10":"EPLHHkquE4luuT9VhtbzO0bv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xRxT7qVSZbSoZRoriginalWR4B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":715,"st_w_id":1,"st_quantity":24,"st_dist_01":"69QaMdONxgiX2lnu1ZK2rUAh","st_dist_02":"5Fqucjr1vMH1Fgg42ZwPcdna","st_dist_03":"gMMJeNufTwBJtI8M6oW9BIf2","st_dist_04":"deslQGJdZG3QyQzc8zVCJNn1","st_dist_05":"F5ctfBjPv95anEoJ8oqR7Amj","st_dist_06":"bo34A5WVPyoVpTpeLyXVYWeR","st_dist_07":"7n1vQf6uKVKo9fGEWQTpraSb","st_dist_08":"YNq95EU3rdTkjNrnIgfZN1XR","st_dist_09":"SEVyuDZAgVjdp705jFGE63R9","st_dist_10":"o5l4HZ78wB3FonYQUx4GFTkw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"57WHeoKbrJ86QDqmx8IydIFGyabTdfbn0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":716,"st_w_id":1,"st_quantity":10,"st_dist_01":"AwgwSQh1jvxu0akofsS7DoXH","st_dist_02":"cAWdNGIv4ChC9PfwNnQVsjh1","st_dist_03":"3fxOqvvyhICZfC6K19BRp03C","st_dist_04":"4TqBSKGQJW3XHm7AyYeVEQO2","st_dist_05":"K39eBX8D4DVvWZJ4goKxjRcO","st_dist_06":"WjVY7db2y3khTJDkTDM9XlZ5","st_dist_07":"4OwOUTV4kxBeUdARg6AzGM13","st_dist_08":"wBL3riwFJNj77Qi3BHQbBKqN","st_dist_09":"pAolJ1uoGAxuPpzC0odugW9b","st_dist_10":"gIeJeT10a3ReIS8Qtezg1r2E","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4yQh8y1originalvh78VM54wyAH50CN648"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":717,"st_w_id":1,"st_quantity":78,"st_dist_01":"iivV8C0G4XsUWLp41e5T0mIc","st_dist_02":"Q2SJPwtkw3tRctFqqM1uCroo","st_dist_03":"HGvG3XlC8DlYP9O7XFVRe1iO","st_dist_04":"UTGYxByGqtLAcxxpMzlWDgwx","st_dist_05":"4O1wMNa6kkkQdLdRQyCjHGVf","st_dist_06":"9qxyIgMfYJZ6GmLSbNxxgfr8","st_dist_07":"hmOVSDFvrQTtMMAdeGEqLDhs","st_dist_08":"7RL4O9TNErmdY8ehTNAD2aRo","st_dist_09":"DzkpooTC4rkrkVnhIrlGVcbW","st_dist_10":"OlfSRJjCQO4ishL5SHcHAdBg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"b0bMnXrqaxfHYHU5yBHXc4aZ7wHZKNJ1h6wN5bTUiBXFi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":718,"st_w_id":1,"st_quantity":14,"st_dist_01":"LKZFyOIfYae0Nj9MZRt4HMca","st_dist_02":"WrPTNRcELfXhl3hxT3zikLv2","st_dist_03":"9kNJGRx2nEcEWYHpOXsFa8l0","st_dist_04":"ALgXDBmUzV5x0iukTjuHKFGl","st_dist_05":"KkqLhIYwkxn1XLpFxBzDGX20","st_dist_06":"8Ih7eontbAZp6h2bCNr7IQU4","st_dist_07":"9Rf57dvKKEEkg2VcKkNAHCaR","st_dist_08":"XlgP4CTeknzwIAnMLKlRN5As","st_dist_09":"CiYVcbJXuO4RrLULXulRZ3yh","st_dist_10":"VDR3ceHTFORZVvwJiTd0X8fQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NDwbeE47Lhivd3RuxQd7YZz3xaIa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":719,"st_w_id":1,"st_quantity":40,"st_dist_01":"sUR17y8ufGeRVLXoD1rWNNt0","st_dist_02":"EFy0nJz5bLuiEzU1BEcsUSV8","st_dist_03":"zkyZhnqlCAIXr7vqzuXdroGF","st_dist_04":"oQ9IlMsfabp3eaH81Xadxf5m","st_dist_05":"6rVl61wjmmPBKW72sqX3ZRjg","st_dist_06":"qteMdMrFaiaW3N8lr4v0O5ie","st_dist_07":"Gyq65iKOso3Qb2qDeYl629uw","st_dist_08":"1DH0GipNsAn4MU0U7NKYmJgE","st_dist_09":"TPHOpgLx9edd3tIeeCr8nsad","st_dist_10":"JZ7cm4NLPGpjkGQsEEuy1T2S","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aHPbFW5l9WWVJyWPSJ8PhyNsGtXzF1nA09j4K4PfZUREY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":720,"st_w_id":1,"st_quantity":38,"st_dist_01":"FHA4hZETaGgKXhAkvTqXnEhV","st_dist_02":"aF6R8ZVMLCCr149cHMwQA4Jl","st_dist_03":"hhdIkR19rxROs2UdFcE9QalE","st_dist_04":"NVzs3PWPOYzsEDb5G2lfzdPw","st_dist_05":"XGn7JTdnzz4Uzpsv91kxGiFV","st_dist_06":"UyLDAnmVe3rV7vNT2exiBtTi","st_dist_07":"LKMKne1m58MLKdLQX2iytjxz","st_dist_08":"EtLHFAlvjGcKuNYRzeoebQjI","st_dist_09":"BgxdYIMHmQK7Bv2AlYaTRvlw","st_dist_10":"IIRCGWSVU2j3CizOMwUVmAED","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TfmxlAp5xJU0C0dT0TpNh3R0YHBcyNtiSuYtWskHiALi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":721,"st_w_id":1,"st_quantity":17,"st_dist_01":"XrWCDKKaVvZ49jEz4uzdXa2u","st_dist_02":"jxGrdgvycdWajqzMdvWMw9To","st_dist_03":"TN4JhZ7NR4Mhi33yrCvSOBGh","st_dist_04":"gPwoUseyO1E8SePRYRZFWcVb","st_dist_05":"0Um58obzX5ks0K2howVu46wX","st_dist_06":"44lpj2ICiEeV2sk73GJ5n6QV","st_dist_07":"zBou2rGNC4GX5zTqbN311u4e","st_dist_08":"gUKSpePiBhLXleVVjn3KXRvl","st_dist_09":"1E7stHxuaFHLToxG6DxP7LEf","st_dist_10":"SYciWkpGRu8t5bSXFnMmdygc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iB5KmulOkafYPgNlIOIjb4wTzXrIL9AiRMLqQadG8p43jRvDa1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":722,"st_w_id":1,"st_quantity":98,"st_dist_01":"CWMqtBMCRzMBBVYwHR2etKrT","st_dist_02":"N5VE8VSksupAy5wkHFfyqvOm","st_dist_03":"giMNlfGaVLFq6nAHALjP9V78","st_dist_04":"JyxI6wNFOrr4tb5w8Jtx14V4","st_dist_05":"9xXm4SzLKAWMxOJPDjzMH7I7","st_dist_06":"neHNfGD4Q8AR0hkh3ygopIix","st_dist_07":"v8yomjxdpo5KSJpBE1HGIUuK","st_dist_08":"nk8Os25VINhF3eZFFO9HO0rI","st_dist_09":"v6FxYBWQuJ6GImibJnpt8KQa","st_dist_10":"zX3qAtRfsJUJGYl7lDa47nKd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dq8aBRl0QgOxFv0AsDqGFKKyvr1BDz3e8079jhRpmpw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":723,"st_w_id":1,"st_quantity":58,"st_dist_01":"55CmtVWmZycMPO1lWiRiV8H5","st_dist_02":"7iuCaYmXwEqhhEOHog8fMMEL","st_dist_03":"EoCnAhR9XuRV5elakeYZhVmV","st_dist_04":"4GnnD2d4HzPVFgjFnHtyM37T","st_dist_05":"tgHETWAeopEoSzCgw3Jnxc2f","st_dist_06":"sULX9zJEU6SGmAWALZ96GwZV","st_dist_07":"N0BBSJgEBFCOjTbUFCw3O32Y","st_dist_08":"DhuCTFWKbu4xR6xEgfWHC0eT","st_dist_09":"lBFLOjoae3oReuXhPaFbMMXg","st_dist_10":"LyKYxYUbHr4DkBbIgiWMFu5D","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1xgNGYuQH68JqnSAFUNSww1tOKJuJaxzYj96r1mnSFyJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":724,"st_w_id":1,"st_quantity":42,"st_dist_01":"pbLcEV1fT84dFyutfwHrLjSH","st_dist_02":"b7QG9em5wj65axriClu6I9cU","st_dist_03":"iheWq5qFPbKVzxL7f6vvqcnk","st_dist_04":"MAcKAEvKfaOiuRGBT2ZlvlCd","st_dist_05":"yUHdEOgZqhOU96DhWc1i0i8I","st_dist_06":"K2MqiDTSvAnwVlnKV1kF7u1F","st_dist_07":"kO9PJUtOZd6CtEKpDs1YMuvj","st_dist_08":"bjtwq87TwAXGwNGHVNRsCPxc","st_dist_09":"upZbW4Vyqm6ktdQMXTl2Qs10","st_dist_10":"ix1KjJBKYkSX1Py7YoBHbJrH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9b21ZNp51kqO74PkWRyHHmQ97SFtucV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":725,"st_w_id":1,"st_quantity":37,"st_dist_01":"lTuLkwNZk3Zt9PCqL4jWC7FN","st_dist_02":"OHzAh4KLpfwm58EehUcLXSsq","st_dist_03":"70lNeye8RDS7vsCNfQ63sF5w","st_dist_04":"E9S3wepjvHqwMJ3BlfufC2sd","st_dist_05":"d6OkWKrl7DePmhsdjfHcutNo","st_dist_06":"qJfzLa24zT5Rd9ELoNQZVncy","st_dist_07":"w06xmkeb5mbo7OlK7vi1AVbd","st_dist_08":"6NhFNdvHH5naDZXZ9M7NvgIP","st_dist_09":"o4FwIysCd0jSRYHY7kFCCPeC","st_dist_10":"KJSDXKJ12xmqoZLFo8XLVxYG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wLgR9YbCvpPGYwIfOe04RU4pSQ4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":726,"st_w_id":1,"st_quantity":42,"st_dist_01":"yHAqEx3kLMUt6u8Y8vCCwvKJ","st_dist_02":"O9aolHwsnPhopODpV88lE5Nx","st_dist_03":"eBa60IvsU8w40yj1CG10FOsd","st_dist_04":"GmdTWt3BncbkR4JLV9SCJKpM","st_dist_05":"og3KUD2Cf0NloIlcFQQyaLlR","st_dist_06":"IjAmaxf92sfk4zY3IB2Njh8J","st_dist_07":"2lm2ADzXweb0Rkb5zQwzT2kj","st_dist_08":"FHgRhfl8LUBKk6IBbriHaSu6","st_dist_09":"MbAWxeWBjdzo0V0z0m722k6B","st_dist_10":"Nqhp2599lzD0Fqbf06nFTVkl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wentnrTM80rh9racDYRyR1CWanhsFq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":727,"st_w_id":1,"st_quantity":11,"st_dist_01":"z9Vk3cGRik23gd1iM3psRJns","st_dist_02":"GPCFsyRzljKgrPZ2kszL4yBc","st_dist_03":"e9UWb2BuhzsLzZTIU86Vs1Nq","st_dist_04":"x5Epmfz1liQB2pM5ZB56E2xH","st_dist_05":"SA06XSulvuUfBz1wPC979Ocg","st_dist_06":"22STzmaAzJSWqW6IbaNUxBby","st_dist_07":"rTnLcZJ6IMLpevaUH74K6zsc","st_dist_08":"nfn2d34Hxkky9CyezUU8xxHU","st_dist_09":"dZSwLWLp04r7Iknvm032Rdtj","st_dist_10":"T4CNdDiOtVzc8L7uQ0nWmjde","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DXqF7IslGUetSzlw6JTBtSVEjZpueXz924tpKI1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":728,"st_w_id":1,"st_quantity":48,"st_dist_01":"dEOcsy55k1op36dKh6ietsqb","st_dist_02":"Ogbz6nCsWuj8jWLegsNXXqzN","st_dist_03":"zQlwtW6xlJFOhTPurqgRKNeO","st_dist_04":"TjFBa4udjiQSuDSDcU2uEXka","st_dist_05":"u2QJ2OY4JtlwI0dEE3gXQ6D7","st_dist_06":"kT8dlp4j5xuF8PTNfVVHNePq","st_dist_07":"f07VKTDJ5WpiL7ULtWwjOvmW","st_dist_08":"rezpmp2UF6PMrtXPsantC1s2","st_dist_09":"nJdzY4nEMiqDhaxVwP0WvGND","st_dist_10":"1vDZAO5qqMzEukuBdHIqGPdM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"G4IwxPxNUC9NNyPKtNQpjyPyHqlQtSTP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":729,"st_w_id":1,"st_quantity":13,"st_dist_01":"bFLyDeacEdcxFV7nnvri06Ok","st_dist_02":"0EsOq5NqMm1TJOamE9lDdEy4","st_dist_03":"Hfp7Wbehf0hNgVcAE9RXOEY6","st_dist_04":"wnR2r7yhVGqHnDUN88MxksU3","st_dist_05":"BqoOSENr5IeWeEgZbs7zWqt3","st_dist_06":"Kq3A2wu7JEQ8vqOOr9KSiZfk","st_dist_07":"bbihy84JyQiGUYAUgzkqv7TC","st_dist_08":"wBdYbR0U7nQgomFGq6091ari","st_dist_09":"H0WEsqA6wC1zq3tfCOhFvMex","st_dist_10":"X4KngFSBNEwB9tMUjfgblkcU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QtcEGpGoriginalpYhiDQMXAc3ofezDMGhBl7uNr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":730,"st_w_id":1,"st_quantity":57,"st_dist_01":"PiRPZvx2Yv5aX5epwmZpZ06i","st_dist_02":"y2RtdGUtoJWW1eAOE0mhWkgs","st_dist_03":"I1UuU1nIcrhwa4i4hP8c1mjr","st_dist_04":"TTOV8IjXXRSFRpN1S0y1onF0","st_dist_05":"UwfneVKyyNOvihgvlhK38SSo","st_dist_06":"jNvzl1QmFoWSn4AQifbEfHhN","st_dist_07":"IQNJsg9IB95uEZ3pLygMVCKz","st_dist_08":"AMjQhZuRb2YHQhoDWOSjLiyq","st_dist_09":"qmrcI7ivAd0kWdoqRLZKvxVL","st_dist_10":"uv1ROCU8GBNmOl32BsOQ9nB6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Wp4MqUW8rId26LB3Z71IeYZnxv4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":731,"st_w_id":1,"st_quantity":36,"st_dist_01":"ViUBXVfor7oDuVG27ss2fDDy","st_dist_02":"5PflYsimWWpv3OWolqjV8UuH","st_dist_03":"ZoX3PC6eUwAUFdsyvgD88xot","st_dist_04":"8nRof6XygIIdfcr7iiGqHbTL","st_dist_05":"DRqRQGc34dB0rk1GYdaVneaS","st_dist_06":"Cf4CZdSQC81yXPBSwjIVCiW5","st_dist_07":"lihJTFU8p4RffFB5nhYdJ8F3","st_dist_08":"MP4iWpmtoyBJesQ9qNYgN5z7","st_dist_09":"SdF5hhDeZzP2tuepPJLTUijo","st_dist_10":"htPoosaP8yiVUBRIREyhXLs1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fGs7UYgqDDPgCrrfbywT1jwp1t3P9Loriginalb1pk7brZG4Hv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":732,"st_w_id":1,"st_quantity":15,"st_dist_01":"S2LtkvUKSqmRC1YA4DsC5pGT","st_dist_02":"cztJCJ82mUSttXKyzXLpzla7","st_dist_03":"RLYW5b1uCB2Xk0UzP8fp9kVt","st_dist_04":"q5OTLQUMuhYb6RubVWbGqDGL","st_dist_05":"bKco5tIrkg9TL6HT6owpZ7AF","st_dist_06":"pSkCejT6mgyBp2vDT8UslUY0","st_dist_07":"tKAeyBEp0JcqpgKehgh9QVjA","st_dist_08":"3I1Q9AI7X78CkmfrZRncp076","st_dist_09":"9JzOVdEvH1pSYwFDLuuhfW7A","st_dist_10":"Httxf2eXeaYsZu5zbi8CSXSZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"s32C6In0XfeymJBAxvN5KxPjpwKRjmnbqd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739240,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739240,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":733,"st_w_id":1,"st_quantity":54,"st_dist_01":"K6WTswn0zoDWsibmjSq4vehu","st_dist_02":"DmLCdnpfAgzDDNZbdUmFOcoH","st_dist_03":"yD0FQ2cwwzJgCeR9l2ISfztZ","st_dist_04":"eZ6pwBVx5JbBnyoTrJZ9WFeJ","st_dist_05":"m66NVX3VbGi9pTdH2klsPI6Y","st_dist_06":"ARyUyirQle9uYGj9reZPH8ZI","st_dist_07":"hhnsD1LWObHIntqeP3iWFHLx","st_dist_08":"iBepT2XtYwNY98hVdlPmuiNN","st_dist_09":"8evq1LLo9LOunKUtB6BeEtB0","st_dist_10":"6uFuss5lB5Fhb5OmFwdaPFK7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8coriginalBDXAzjXkxliJoZzMDgv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":734,"st_w_id":1,"st_quantity":29,"st_dist_01":"R7zWAjlmV7JXxey1x8mD2GXT","st_dist_02":"aGTbqEbpHpaD5DQm3r42kYqu","st_dist_03":"jsWGBsrVsWt6VS2zbPIwhyf0","st_dist_04":"bIpPHpcquKqBRXObaHzc58nV","st_dist_05":"Fnuizkbyk6ArRGzMiE0pL9kR","st_dist_06":"Hn0v6fQsl0ZWB88oKMWamtYb","st_dist_07":"TSQJ77H7jUIipG3ozRKBmx1q","st_dist_08":"ObNyZSJxxV5TaZjQ5bdZEfgh","st_dist_09":"5xQrdmkqQ4AGDzBUtueOTS3N","st_dist_10":"rL92uO3jLpTPKIYYYBGrTDPo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qFtroePuAqZ2sMEhJc4QUavJZEZ88NGQ5Mw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":735,"st_w_id":1,"st_quantity":75,"st_dist_01":"KJbOWtbaMAAHSY1f9hP1Tqf2","st_dist_02":"dDLm3bGCVvo91fm1tDfSmXOs","st_dist_03":"EiODZwx1hoSMJVjaE7oZO9nT","st_dist_04":"qXLDtgK8dKevjHR5hEBOpvNF","st_dist_05":"dgaNwBOVoB1zaruD5gGzYdU1","st_dist_06":"otgwRAJ4Qt6ZqrA73WyzjBZt","st_dist_07":"E0eI9mQN2tSPSi6Fxn7SNQRs","st_dist_08":"L2SoJ59kbfCJqOXofqTchYLE","st_dist_09":"VaOXxbTUZBDeVCeIrG0AQM8h","st_dist_10":"8Wl4fHCoPuXhuosmmsSjRZm4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xY0AJ4VS9CX7uQ6L5mZ3ZkGpTGsSyw3doriginalP4SjQV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":736,"st_w_id":1,"st_quantity":45,"st_dist_01":"1qRarrSoZG74YOeR1V58NByZ","st_dist_02":"olydYnuwtlYZluaWk6gMsfvf","st_dist_03":"qhNGeqn32q4g3p5WRzaA95Ly","st_dist_04":"WE67MPzv1KOJuughXTGG81AP","st_dist_05":"dO3PD7pvle2jALh3bwHhSl9f","st_dist_06":"43zJKf8vRtyRa4G0xh8dVEVQ","st_dist_07":"uyYP7mUmE8E1KF2Y9hYMlJYq","st_dist_08":"jrJivkHOfw2FBMSfb34RwGPY","st_dist_09":"mvG9AERNJsXDRU08IswwKL5R","st_dist_10":"8wjSVVhMJnFIPpvdcslg7das","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"caN8Lj476x5OGPcdXNWCPXHTFx3wPzm9LZkvI6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":737,"st_w_id":1,"st_quantity":54,"st_dist_01":"6c1YmGxD0R0EUr2aYDJ8W9gX","st_dist_02":"xZaG1pN65HaHr7hY38cJRrQS","st_dist_03":"pRw4Vibm22gt1PPvh4fbuNNX","st_dist_04":"AS7Xh0Ro5LfXLKci3euazmGS","st_dist_05":"qMAQSVGWw7CPq1NX3DYZJwXr","st_dist_06":"7chamcZ6GvwUs5GNwgXWGGh3","st_dist_07":"IjdVVLVLGrXoo2cre5ru4Is2","st_dist_08":"M43mLPffm0cDzADK2EmCzJ2n","st_dist_09":"91n4Y4FJudtS1FqG4ySSDVZs","st_dist_10":"JkaZygC0buGBkDcPh98ujONH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HqLH1zJJHlHCSnuPSOCXaD8CATGlsr8cX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":738,"st_w_id":1,"st_quantity":89,"st_dist_01":"Q63kfJElvkQ9KyWmOYBOSFnE","st_dist_02":"VWcitiE851iDlglEJGbx1U05","st_dist_03":"QD8UisazmwsKHmdZsJwHB9cR","st_dist_04":"8M2urOMqfE6CBrb3ESjeqBhg","st_dist_05":"aaPRiyNMlaPlD1MPMPDOWXDx","st_dist_06":"sC22D9dshLj5yUPw1DNA5hHy","st_dist_07":"nf0ffCvlOtjCLIXu9BBa56ka","st_dist_08":"FKnjINo3R4M9GWb8x7crSTVv","st_dist_09":"Qxm8sYm6g58ARX5zeYtQ9n0f","st_dist_10":"IzCjrwcGsz1OoPjI7Ge5VCPo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iLsNZh8v3zJtsMKlW4JAbTy0h9Mjgo2Ckp1aUm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":739,"st_w_id":1,"st_quantity":39,"st_dist_01":"7RQp1kXhX1cGZ3xhxYl7PMAB","st_dist_02":"sY7P24tREXNdf8kzf1m7Qaf2","st_dist_03":"YskBZkvgHkzxesDw5hbVx9Zm","st_dist_04":"QatmB1AjLLVK4qZ6IxkyciDM","st_dist_05":"kqKm2nkyn9zYIzacAevnOe0K","st_dist_06":"Ftoen3RBrA6hCjOwpQ2pcdx3","st_dist_07":"P5zrwtmt47DLlCc20B3kzdvl","st_dist_08":"BJADkjbVUWKQpQ4IKGyylznt","st_dist_09":"K3PbLniVeOP5oapgIgznSkNR","st_dist_10":"Chl9N56OOZjTAah183SPX9bP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ka56bihXht1haGiHcnIRzADEX2eAXtclK5N0S9l2WSK4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":740,"st_w_id":1,"st_quantity":40,"st_dist_01":"BfU3BQXQe7K25nlRSP1lt2tg","st_dist_02":"5R1C8NgAaA0d4QOET2dMq3hd","st_dist_03":"A71Iq04GzowSxrdL0BvsOnGr","st_dist_04":"3tr6I6P4qZy2Z1f6YLG1Gf49","st_dist_05":"7NsgGnSf0CGKvGEHwpQJWZp7","st_dist_06":"KxCxfDqz5JpuA2HqxUsQ5ni4","st_dist_07":"G72V7UPS0JyzJLfSfbR7H65w","st_dist_08":"rOXTQz7WKtE9yN3tjz3WEuQr","st_dist_09":"HTkg6CthGMvE4OJivjfEkv1q","st_dist_10":"GQWhXXYXYCBi0CTjKhPidwUE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0vxAsoYZIWXGSMn1HlxVn2xhJM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":741,"st_w_id":1,"st_quantity":52,"st_dist_01":"KaIgxaqs4y4Fi2Re0G3O1Jtw","st_dist_02":"WDxLaog0ZbNIpfXF60XcybJ9","st_dist_03":"nc0Gcktvt1SlK2z5IGu9QYTd","st_dist_04":"nTuIEDWOvbLyEMQBGP0soxrv","st_dist_05":"0xDjzz9PzlDt60nVKGAFhzLm","st_dist_06":"bcYgpjSk16yU46HZTrnJTT2o","st_dist_07":"CUn2UcOVXLIrgHjzRBcjORFQ","st_dist_08":"13f8vIrQe3V84f96B6vmGslc","st_dist_09":"gOn1BXolOPMJ8svULgOjBlwU","st_dist_10":"Qa0AjaIhsSVSB3KTaSWuIrRS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5wpwko60ajsFphfY3U0cmkqQDaalp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":742,"st_w_id":1,"st_quantity":48,"st_dist_01":"ok54wcJSUiCEB5cTsplauvmZ","st_dist_02":"5CYSQhS4Gnpos6zuLChP2VWJ","st_dist_03":"RPH952ZoIfF6onl5KScVnB8X","st_dist_04":"Qb53QDKL2g4yL45B7SepyG4B","st_dist_05":"X01VklmCKqzyZcGFR5ussygL","st_dist_06":"1M66ynGPVbT1diyBkwkQvhRX","st_dist_07":"bobZj9hNawPgeQjwhM4G6OlU","st_dist_08":"7OyjxpoOjw5UAQXJGmnQEHoe","st_dist_09":"IeWOjswbD8EBHpnLnOXUtZFb","st_dist_10":"gaUvNYoctPSc3oL07kRYnQyY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RF60d2yl5OItPnE4wC02v2RsclrZFLFf1V45s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":743,"st_w_id":1,"st_quantity":52,"st_dist_01":"JN1SYgkmW0Ec1ISpg0TEVs5M","st_dist_02":"Db0odCvf5yrot445QOE8LN0F","st_dist_03":"3El4X6yknKGcsNgin4xCxHxp","st_dist_04":"Ta3ZCnYbpljqU1m3Nunuq22h","st_dist_05":"q7SX4d9JrcXqTm3jH7c7Kv6V","st_dist_06":"62nb2PGlMIjEB5ZgbVPRaF9B","st_dist_07":"riJXvIR5WvqHjeqBfym1F0U9","st_dist_08":"436Ph8RWCL9eECyoKYqEn1gN","st_dist_09":"jeO935rLfPB1bkH81xgVI6i8","st_dist_10":"SmfqbjcfnBLOBldiTGaJinko","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0xWbHvshF4X8FekFb5ECOfVOwW0EFhp7h2laF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":744,"st_w_id":1,"st_quantity":34,"st_dist_01":"76wqEmBP5GMu6ZBCYi7CFXaN","st_dist_02":"8IsKQXzQs4CKQR2ffzEcINv4","st_dist_03":"sdrxe6MtuiKVvnzZsPu7l5xr","st_dist_04":"c8KcdJkZnHCAphdhNLHZN5Sv","st_dist_05":"2XHXrVuhUdXYnzmFXoecgDS5","st_dist_06":"ch5sCG6BLI3ovglJKT7BxG6W","st_dist_07":"jHSyhbrhunktZwuDr0IQS8Ik","st_dist_08":"eHy0Y9qE1o6DbnZV66DI9w6X","st_dist_09":"9cDLE0g7nqesqSjMRN9wVsRI","st_dist_10":"AHraFxXf1kQmdvEj3AnlYcvw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"q40q1OTdS55dCiBqSBlHPSXVoJz46eC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":745,"st_w_id":1,"st_quantity":43,"st_dist_01":"j0ILD7DOsT7Rpt6J03wZQlmd","st_dist_02":"Tu1kKBVMGnufWRLIyNiraOWF","st_dist_03":"vFsAABHkPtUhMM3aIrOlPva8","st_dist_04":"VJdHEVO9cF1OSImuWj6nkh8Y","st_dist_05":"tTEpSOQXgZ2NOOm5EG6zgwpZ","st_dist_06":"sRRcCw9u7yypJVJhtqD2jMh0","st_dist_07":"jEPYn1nxXF0WCuEGqoCNJTxT","st_dist_08":"IzJOg2mshPTMOddqGTwonMpX","st_dist_09":"GodGbK6URmuvZiiLtq7BnLa6","st_dist_10":"TY55Tz6ZXR2712t7lvxUjQTx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"n5rIiiWR5lGtdmhOBe7pcCuXZSVOE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":746,"st_w_id":1,"st_quantity":21,"st_dist_01":"PhlaTVHBFQAjzsUSt1Jktyyt","st_dist_02":"e9yedjE2HJxnbvhvFrkk8sKq","st_dist_03":"OiNQthMZST74wWwtJKqsky1I","st_dist_04":"JjbPz8v29csGVg1hfRcDyMKw","st_dist_05":"NtQRHsrKfDLfcEHOl5AUFgf2","st_dist_06":"zcXIbHLTWoDka46X2gT4httQ","st_dist_07":"DDwjZRvRWInNChWCXaEdORsP","st_dist_08":"KYswsQCyt6W8imrNRC9JDMC8","st_dist_09":"b9t2FPQiMcONqkMuEkrMUnm0","st_dist_10":"vUdSL8Ri9QMAz4a7zAuAVvBD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4mlXJzTs09QQ1L2nfgLzgaDoh2ziqcFwHdaeQxik2Cg60I21"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":747,"st_w_id":1,"st_quantity":89,"st_dist_01":"cY2N0FDvnCD4cbveIceAQAV9","st_dist_02":"wHBJyAyt6Ypi6EcGXw0UDZFU","st_dist_03":"OzsjsUjZBbrvkYvE8yRvIRd6","st_dist_04":"zatxSTaGcl5sAI8PmXwRp9dT","st_dist_05":"vALOvysmxtrvPB8r77xNnObn","st_dist_06":"S7OJVgz0P9jbMHOW0lW6peaw","st_dist_07":"TL62OvrhbmpndOHRyV40z8QO","st_dist_08":"5lnenx8zL6ipSb0QY7ZdWLWz","st_dist_09":"B0h7tu44SW9mdz7hdjVbI1Tn","st_dist_10":"D5mh3bM5oCpJi9DjJSaQuwui","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SlqrfqZBoriginal93u3p3TooWK0AMHzQ0VkLIZG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":748,"st_w_id":1,"st_quantity":97,"st_dist_01":"bOHyEIt7Bk5hleb5u9NS1jsU","st_dist_02":"eUxZS4E9SWlKYPM5ocvNEJMv","st_dist_03":"KtjuqSMcbdpnvirW0dOcKTB3","st_dist_04":"jC03qFDR0VJu1DEq3FhXdxqV","st_dist_05":"g4txZmh8tEQWRSVewB9QYCIJ","st_dist_06":"3IQJ8OsmmuZjTEtyErxBDMwv","st_dist_07":"pl935v2yu7iqjTZPhhhJu9j2","st_dist_08":"YYjJ3MrlIiiRt6j2NqFAXPXZ","st_dist_09":"9hCuYU4yfuREsNAoZnMNvG1g","st_dist_10":"UBt1iOu8p72GUdwAh5W9bvjO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"POnwkexaREzmq13ag9w8ZXW3qnpTOA1boriginalY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":749,"st_w_id":1,"st_quantity":68,"st_dist_01":"phQC8E2uKedYrVg75KsfHe2y","st_dist_02":"U83Tj9LLjaYopNIrcOYWVRgu","st_dist_03":"BOzCpkKDa4xFT5EOwROrDlfO","st_dist_04":"ZHwfFw8XQ92vnwp8ui7Dc5ww","st_dist_05":"vEu5mU2zXpceVT9bFGZDOIUt","st_dist_06":"T09RfOpkEDGuxvlGzyrrXIk8","st_dist_07":"Nq95SA06rvhvcOmA8SyhpRhT","st_dist_08":"wN9Poq7gq3R7OrtlGz5NHH4h","st_dist_09":"MoRJzmVKdog6PeMktPkXpzDv","st_dist_10":"5g71Jku1cDTkkxN0cej9s9YH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vTELCiblH4aGBG9n5ETxd2GsaYoSn2PiIHHfQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":750,"st_w_id":1,"st_quantity":58,"st_dist_01":"xoDuJExWQqyvfPr5RP2PNwp4","st_dist_02":"7487MCbyPceNqvl61AtlSRKn","st_dist_03":"krcWLRvK3hEpywZsdYg22jaP","st_dist_04":"xRqXu2uL8Esx2PFUyiKhSc0X","st_dist_05":"FYmaCKQHcvQFtZAZdtROZAKn","st_dist_06":"NzJQEL9XKHd40yD5OdhsaYSV","st_dist_07":"bm0k2L5CCllP1EF7RZrv1VT7","st_dist_08":"D9MYuuhWyFSDF0DiJrQViQel","st_dist_09":"wJkcyVv7CyzmPRGwF3N3Eu3r","st_dist_10":"F8LNN4gvCyMuixd9lBOB90X3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cieK6R8QAT0D8WPKmuuDmWZCE7kwwl8qUmBGkqV51v7R7wLS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":751,"st_w_id":1,"st_quantity":35,"st_dist_01":"Ub8P19HqKL77YH5ARWr6DKN9","st_dist_02":"0ApSO7ADB0Q0qPmt6Fyk3qIW","st_dist_03":"MKYFoT4NnYnbgJr5ZwLIdrlG","st_dist_04":"pRT45EiEcqXUIJmqEAYFxMxu","st_dist_05":"9HJlWHRrPp5aj95B5x6PQXmd","st_dist_06":"p1aKZ43Z66zWeBIWGyibAjvJ","st_dist_07":"l5l2xnSlZEnW5b5Akwoy8X6x","st_dist_08":"moNlKGUbg0Df69ave20BbdMJ","st_dist_09":"tayvmNRaQqavASpSpQDkeAgQ","st_dist_10":"bPIzUu968puTYjrTwdIgxaci","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lwSzKvBoriginalfhVfxg1hdns"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":752,"st_w_id":1,"st_quantity":90,"st_dist_01":"dlWcmT4Pm9Am2y6oDShtvvQB","st_dist_02":"STBOP4S5YPrWmu8XI6eLy6Oh","st_dist_03":"8dx2OaoVqtgUYSURP18TdT69","st_dist_04":"kkOaSqrF3XO6lBqVUzidGfLl","st_dist_05":"7cYttc9iVVWI5NByN3kAv57o","st_dist_06":"pOjo7EGzylz5vxdPBzhqAIJb","st_dist_07":"h6MbUso791MF02NfV94E6ELS","st_dist_08":"hC3kKDu5DCfb2ifTiT3UqtUP","st_dist_09":"2F3g8u7YtnBHr3GrjvACLfsw","st_dist_10":"lLfJeee0tLltVVJ11rTclsA6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TObLwtFJ8judQDRxtyx9hxTaUUJF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":753,"st_w_id":1,"st_quantity":54,"st_dist_01":"pz1AzrIxEKQNYHLrR54X3V8Y","st_dist_02":"DDnpvxPYLc7agOfJDenaGfYh","st_dist_03":"wuO15lh3uEUdyJPw7tR3GFjb","st_dist_04":"kvWWiMouDFd7jd2xr4TIrlvq","st_dist_05":"e9I5vwmSSwgqldKKwImhv0Fg","st_dist_06":"2kNY74M6rqs7gihNyzCkHBgN","st_dist_07":"GrixM1Cw4P7KSNO9iT02OwGY","st_dist_08":"hNCM3n6dkMsafLtP7sKI9o30","st_dist_09":"p9rwA8ZmvpJmnucuLAVt5mOT","st_dist_10":"sWv07Cj1jj5guYRH9SgjRqai","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zfAwpTROomO6cEtGGsfnHXWeEuhmHQRyPVQRnPYB3bAgi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":754,"st_w_id":1,"st_quantity":24,"st_dist_01":"4cVgddHgELOoqlbmkb9D4pqG","st_dist_02":"ZvfQ5tHkqpkwsz4oVpQgCvWE","st_dist_03":"d3hbBtANH45GPeVdAZRJoUS1","st_dist_04":"AVrTVTSj9dgiVnHs7ozyzDVw","st_dist_05":"YsoXqdVS6b0CXMuMBRbuLb3f","st_dist_06":"sWCmMnJhYnwhCDAMOmHeT9TI","st_dist_07":"bKmoJOagbEjR0XgWFpa0NZbN","st_dist_08":"fINXQ7eGnOmaONFJ3iaBiXYb","st_dist_09":"tW5DaZ4s42QwVP3FNAKNVTwN","st_dist_10":"KExxeaRVu71VZiYCLVKhtpNe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bg6Kzl9xWaNQx8OezWgDmv5mhisVRf2eiWrr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":755,"st_w_id":1,"st_quantity":63,"st_dist_01":"3nlEtvovwHJhfXYYQ07OQtAj","st_dist_02":"f3VjYRS31tM3x8ejEseYcVhB","st_dist_03":"mSEzndMglDn5Rz2Tbr2pUPQB","st_dist_04":"jRkEbbPvSI9d62v6pghm65t3","st_dist_05":"JMrkH4M5YlL0tlSz0kAAn87K","st_dist_06":"96kCmYbmQAfoPD2jcQkja5n8","st_dist_07":"kiRT1aLEEasH2qX2UmF8FsdR","st_dist_08":"QoPDI600NS5gG5YgUNhTsIQw","st_dist_09":"j3dnVOabimOG9JhRx9e6Znxu","st_dist_10":"b2deWASrh39UkHQWaXYnHQQN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"D5e0j42DIo8qd7ASJN9PWx2yQr8WnbV8niELGOy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":756,"st_w_id":1,"st_quantity":33,"st_dist_01":"5qtqLuuCyadRkfwNplfjuudE","st_dist_02":"jLtFXx2NPQJ3hWZfNMX3EFH1","st_dist_03":"T42ucGKeEM7bvUvIEZ0NZWQe","st_dist_04":"z66Jw7vvBuw7m0qwZoJiVvW7","st_dist_05":"kcCz9e7t2HvERAhCEquwb5Sk","st_dist_06":"spNEvVgNea0FQ9mWqu7Wv8pX","st_dist_07":"EvHW6SrXClKWMcfdD8u9fKcJ","st_dist_08":"ntQZTAQZtfAoleEtJcinYZPO","st_dist_09":"3CkCtaqk2VW1FgDTA7kbL60n","st_dist_10":"6cv21SXDb8MybS010xbSkLk1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fmPe5ePcDQTOHezqIBHyou2NJ2JXPNjhj0rzxrW0OLIR24WDhx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":757,"st_w_id":1,"st_quantity":81,"st_dist_01":"BUR5Z9vbwOeSoBrDduRyUeKT","st_dist_02":"dfdVjabyTiSQC2ZSyNqosdTn","st_dist_03":"FnFUuulnxcF1yWm5Xr4zjsHQ","st_dist_04":"5uygHknCA6x7SIahY3i5Y6F6","st_dist_05":"8v8uGiQ4ylqJEPcAxG6rMWv5","st_dist_06":"yaRB7ew7R1gaa9H0pqaqwOz1","st_dist_07":"tObwtchHLzzio85J9kNAXBhz","st_dist_08":"NrG97qwbtxxQraoPTRtd4r5v","st_dist_09":"wiDU1zMTzf06ziMc0dA4ghD2","st_dist_10":"VEyenpYMMHIHqVPtqg2COWKT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AGm61rGNSqYoW1ZGCyg2adIw3RE53iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":758,"st_w_id":1,"st_quantity":88,"st_dist_01":"FGidoLX7xtlbou86dBO1ogna","st_dist_02":"HgcrAXhZL5mDhF7CIM6FZO5s","st_dist_03":"ZQK4yJfTjn16erPmoiHNB05F","st_dist_04":"uUq5wQDKkeoFIVbeSEBY6qtb","st_dist_05":"01YWYErLuEI6HL1ziY4x0uL2","st_dist_06":"ZC7gBv37kU9MstQLCksUKRix","st_dist_07":"ar2jPWBMsss2l5luBhBZ68yw","st_dist_08":"SSmuK1HFOcacwMD9u1QFSPz1","st_dist_09":"tEbwlxuaGtUOT6UiQAMZ2RpA","st_dist_10":"8AOo313RuDLcNRAIjpoqpPV5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9UhYhan1RD2ZnPCdxl5XJxyg5Gri3N6LO7ti67zvvhaVL9M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":759,"st_w_id":1,"st_quantity":19,"st_dist_01":"YSzd8Hd01Rk6pXJuVtks82LN","st_dist_02":"5CezIqfQtKGOQKtQ77B5FfJP","st_dist_03":"0oO32WqcYt7XDEedBXFVG5WG","st_dist_04":"DPLtmqDmXKUczOXN7pyuNt3X","st_dist_05":"HaTU5utLV8UcMiuUOxkSzoQX","st_dist_06":"gVqXcbpkh1nWAdCYxEEttMpD","st_dist_07":"6EsraUg6sMEvddB8XmOz6HdQ","st_dist_08":"Pa5MFZZEsFlgJf2TKNbBlnhO","st_dist_09":"f8pdY2evCdT0P7G0KEwQzlcQ","st_dist_10":"nch9VTvx2LpgnfsQaU1AnABw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"X4kBNXCnSfLWSzFZWephZrEk8G746YLc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":760,"st_w_id":1,"st_quantity":38,"st_dist_01":"lgC92wm8mmbnoDDD8ofLSGtQ","st_dist_02":"lGqIKIcCmZSsEl3JAyfMzcoZ","st_dist_03":"0qXAsl5HZtL9cIfSQdZIP2cE","st_dist_04":"VRXHWVPZlsy3QQRD0QTulPcF","st_dist_05":"GdruKB6fOyo7WoSrA5gi6Ty0","st_dist_06":"hkpHhWqYqglgLIBkBTvkuZqQ","st_dist_07":"1cevLVLnweYbvIr6WBkPMC4C","st_dist_08":"8chtPSp9DU4WcPgt94l1sR4z","st_dist_09":"5N0vw2oio905kZrtZikAwR9M","st_dist_10":"3RlwQup5so4mrIoMsNs7vr4L","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"geTD0s34Ev3LLOUDtioriginalML0gWtC9h3rDsHJkxr4bGYFf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":761,"st_w_id":1,"st_quantity":99,"st_dist_01":"CbnAswuEnncBKgnl3O6KYq12","st_dist_02":"aOPHsq0FpDC9M7RL9EQ4WJi6","st_dist_03":"XAn3F05s2rq6iWm7WD0xmbTy","st_dist_04":"vPGVetDhYazBYhFQ4mslcZQp","st_dist_05":"XerDcVtTtSeGyECegLBp0QKM","st_dist_06":"Lo6f6jHX9Gefv93Os41EzoUw","st_dist_07":"BUjECAuNRWvpMpWxtQxc09Nn","st_dist_08":"kinoICZKGvLALR15fY4H4crZ","st_dist_09":"eq900MSRnqaWMUFmjAddS0Co","st_dist_10":"szXOmatRd0RQDtht0QwlOr9o","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"voJ4TsCkyb7wzWvANR4PSgI3Klg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":762,"st_w_id":1,"st_quantity":72,"st_dist_01":"jxD3U8AnD8jP9cU4d5Pz4GJn","st_dist_02":"RngMLhseZB64MJSZ3pvivBtr","st_dist_03":"9CuetMRkSePXenQzxg3VM8BJ","st_dist_04":"ynkz4CKCL91cUmoHAH2EBobK","st_dist_05":"Wjk85YGElNPRq4AbleZ321tb","st_dist_06":"w6GvdRKe2d0oqOBu7JEktKH5","st_dist_07":"0NgxbbJQ9Vr9p5IqVxo4WwgQ","st_dist_08":"jsuwVsNhcrfg2bK7n9ijRzyt","st_dist_09":"hc9kRavwH0pD9RRUiBjZ9rxe","st_dist_10":"hdQHsd79Dyv6ZozKxGwCw00g","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VEnYxmd2T5LdcG1KOCSRowhbRHyYHtasgx4ZjKrbFiTgEE1iX7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":763,"st_w_id":1,"st_quantity":77,"st_dist_01":"oeHaXcTiZpzu3210Ezi0VY6u","st_dist_02":"laiSOYPnepmjgD8a0jVhs8Id","st_dist_03":"Rv6RIrJOX6Y1sNBVracb79Lo","st_dist_04":"LaF7BUFEQyiU7vjdpXjiE11e","st_dist_05":"zXfys960Im33UDJjCeeDJiSv","st_dist_06":"S9URPIToYtoguYlwFDibN6kL","st_dist_07":"5QUKyklsZcrYrnfOhXRLQzt0","st_dist_08":"uSrtd1UQL3HdbaoIJJ3OjaAG","st_dist_09":"pB27WyCNfr3K9lNGV8tFQtj1","st_dist_10":"tzMOdcNapkwv20PA9qtSL2YX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZR1YJH5jGxjmgIODTMuFwD2gM1siIMh3PvjTRch5OLqm7arzwl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":764,"st_w_id":1,"st_quantity":46,"st_dist_01":"Hye2TF0dxwVM1w2T8CVcWUv5","st_dist_02":"Z3RXbnEZv100cwzE5aBm9sJa","st_dist_03":"KYBMkSRXyQRWuVNFG3f5TJqk","st_dist_04":"W4Gr2yU43lyufMIaSDXksHJG","st_dist_05":"5Ca0WqEpGmirCswbLsdDRMoL","st_dist_06":"4E7tIrP9h0tNvgsaa78sV0x1","st_dist_07":"7Sm61KZBDgEqKTjSrN4my9ry","st_dist_08":"R6FM4WfilNQzfqJQO2knFvTR","st_dist_09":"1DW50vtpuqTpCs8zr4w5IC3A","st_dist_10":"j6BPEzda7Nh76UhvsEHc1QeU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t0hHf1i8iKEVFl6KPjuVNYhcHBvFfqjjTgXl8yBHYYuw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":765,"st_w_id":1,"st_quantity":75,"st_dist_01":"NrmRt5dq7o2VVXvDnvQevdpd","st_dist_02":"Xxk6tbeYa8kK8XWaV29ZD8Tq","st_dist_03":"9s4SpTEhPtoz76RFUXtWNg5I","st_dist_04":"arZoRV9RcC7jUgsPwV7JMXSx","st_dist_05":"0eBuoGrm6eczY8T9G0o9d528","st_dist_06":"zTjw3UuDGjbsTxdv87y29K1i","st_dist_07":"hOeG25ehrx8lP6nY2dwmivzo","st_dist_08":"ni6eeg9A8qRDPawE42yKsVlX","st_dist_09":"DydEQALqjeWQretUVzStX0AI","st_dist_10":"YhJXq6hihwuqT77RMx2OBbk5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"m6kwmoql6SKilpXkanrGoC6UzE74I9f6Afu1kVYe7jyVmKr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":766,"st_w_id":1,"st_quantity":12,"st_dist_01":"O7qRc5vITZmIAOdVkyhEMmJ6","st_dist_02":"bPqmv3ApAswPTxbmzrtXGbxW","st_dist_03":"X9Pqbeovd8mzfqivc3zvVo7R","st_dist_04":"0l6keQRObAW99pxwgVuE29U6","st_dist_05":"aYcVraWwUmzUNAth3JQxsHRO","st_dist_06":"DEw9gjYp7A12wqrlq8Op5rWl","st_dist_07":"aPH2wfCCLX8qlZKkm9KApoUP","st_dist_08":"XU9D0YZq7arNnccmOTRAGaKv","st_dist_09":"R5NUdGcUaNSnBGqc9xVGQs0N","st_dist_10":"VNQ6fahfmBDkdkdO5tq5iQCJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OsT2cz0bPpwIYzPuLaxLamHbFmBGXM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":767,"st_w_id":1,"st_quantity":42,"st_dist_01":"fK539sYXLBOAPJ78nypxCHYk","st_dist_02":"y0XnPKztkfQhnR3viIJbCCFo","st_dist_03":"uSI3n77qTBbxSeFQrYg7XqBK","st_dist_04":"gpDKAoeF8lYWgyEMygqRETMz","st_dist_05":"5uTTi8Hq8eSoLwsYNFTtD61q","st_dist_06":"Tn4PlkXmP15pzAPzVOGDHok1","st_dist_07":"AIGsqIElmnQ4Pc4v5O1laTMP","st_dist_08":"8r3UL1tMhZBDnntxLz7XxyJ4","st_dist_09":"sToYGvBaGLxn20CVMOLssuwx","st_dist_10":"Cp90IWuPAXQrDKNjt5flVape","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EmXTZVnfSYfxYf61uBZ1EjpXuX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":768,"st_w_id":1,"st_quantity":43,"st_dist_01":"HXL9osrHN4w5ZetzXPhkfP27","st_dist_02":"dFP8W0nWy5VBZNIX4CE30MLU","st_dist_03":"Dfvx72YnvhYmtkNKILxzgQWF","st_dist_04":"NsWEDNg5NIMSJeStXmNZxheq","st_dist_05":"s1A0c7vKCHbXUEOjqH2yP6T2","st_dist_06":"cBe6ffreFzNppTfV7vkDtlS4","st_dist_07":"09DOsQVmPbHCTf4JCkJyyYML","st_dist_08":"jx2P2Rxcw6PtI6vrpmJf8gNS","st_dist_09":"HNfOgxhCb8wvrAYFpXu6ISG8","st_dist_10":"BAN2pJcC2LrRrbD9sz2WpTki","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"74HRTmUPhJEVJuBQVnPUu8e2pRmq6T7JRscf5gE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":769,"st_w_id":1,"st_quantity":82,"st_dist_01":"dETS1u53D9hs4awaEUAQJqZ2","st_dist_02":"uP0AKbY9Lw4OnfRhmdxRr7wL","st_dist_03":"y2k2An2Mk0Q7zN0eYjLhpQO0","st_dist_04":"GtzIx3GWGxbuQsmfx9RRbZes","st_dist_05":"PdlNTV7ZfKK7tet5zbfqNelH","st_dist_06":"Tftmd0IvYLmqhoyF4zSFUdpw","st_dist_07":"d2Gf7woNKKOeVJXezidkd4P6","st_dist_08":"MeFWT7xOt1KH5vquuv6DyRTn","st_dist_09":"QkOEHVyqXSrW8cTByCBSFVDA","st_dist_10":"tU37aeqXeWQrOBb0sMCZg5w0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lrh2bYjLjaN7R7hBgT3B1KPKwi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":770,"st_w_id":1,"st_quantity":22,"st_dist_01":"Ls40NRlqGzImtDiEY5Vsm3Oe","st_dist_02":"gGHhKme8w8nMk3mC43BDGpjd","st_dist_03":"iA65ctgDIE4WqPzsmk1sa2Ul","st_dist_04":"sYdHKsFGCsON4xRe1nz8t95b","st_dist_05":"LXKUa48In7bvUO4AT5IiajBb","st_dist_06":"ab2zMOVOJkU26QUrHvkFySzw","st_dist_07":"SivYHwKfWZUZHKJTtHUHYq6P","st_dist_08":"4JuGqvg5J8SWzWwgogz6NKSj","st_dist_09":"r1Q1USoL7XUxQFBLglE71yg1","st_dist_10":"1woH1Dd40xRohVo7Kq76pJKo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zporiginalVFKtvds4zFZNGnCaaNmKm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":771,"st_w_id":1,"st_quantity":93,"st_dist_01":"VsVUItnl1iSHShV2sxGEktfM","st_dist_02":"nSDpTQyrWsiFx4VIejfjRz9t","st_dist_03":"gryxxNvHxV3lJKr9qW02Gs3T","st_dist_04":"FICZYkRYe5BeqvtnxsefSBT8","st_dist_05":"nyBQVmzrKIeQEv0vCB8vUlgr","st_dist_06":"X59bjjqxud86miH4vFuqL0uA","st_dist_07":"zHTw8hVnUPQlotIlp60NYkCX","st_dist_08":"fiHAK5YNn8BMWFYkYvJZo6et","st_dist_09":"LfYoUcLfVXc7UwtwKpafPIxK","st_dist_10":"8SC86fVSqhsUkxh3E8JmhLHi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UIDJXLL3g3rRnxEFmWic7XOdcjbBd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":772,"st_w_id":1,"st_quantity":64,"st_dist_01":"L7VCxArJdeOBq2Jllwj7bq5Y","st_dist_02":"OEn3Dc58sPi8rTHgTtkaj2D6","st_dist_03":"JiCr7Wr7zRlEUMPZBMQ1c8RH","st_dist_04":"pseP8ZkM5LWnyQf0xOROsyHY","st_dist_05":"l2F2kjIidoap7u1NfCubOPhC","st_dist_06":"lRj1kcaTZr6WzCYFx54K61qA","st_dist_07":"DZnwisp5nNMGQLvBUMttK3yT","st_dist_08":"klDUbpHmezJFbcmV8FQBhTEr","st_dist_09":"jb5UPptg3AYSHtAg0bnymc3z","st_dist_10":"JUWBUwdv8QpEXc9XYtDPRd4b","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hbHs3SroISJEembSNO4qzGxsRv8zaFEWZTFJ86XWiO221M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":773,"st_w_id":1,"st_quantity":87,"st_dist_01":"nCGst5C4TZm994zwvIz966rC","st_dist_02":"NjTFfeZe7M8WPcNrtQ3vApnv","st_dist_03":"qaW4CqZDKD26kMtIZR2tJfYw","st_dist_04":"XD643RIxRmTmXN2R7zv7ybtW","st_dist_05":"iz2Qc3cPRaVURTSft6r3yNLD","st_dist_06":"XwIOk26RAa2VQlqVkQmhh4Ce","st_dist_07":"FU1A2X0s8vr951mkvRdDQ9Qo","st_dist_08":"QYRWqmsL8N8Zj0x4YJWZV4Ew","st_dist_09":"0l2p2aemVBsDJoePnJeddFni","st_dist_10":"b5EInEYNavxexSXcC9RYPJCh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XQZTc5YgXPAj0V7RpswhIGdqEe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":774,"st_w_id":1,"st_quantity":95,"st_dist_01":"4hN6VhhSGnw2nWQdLZRWvVgr","st_dist_02":"AwGCh5peWnCebSTEgi19TAQp","st_dist_03":"mCSLIaxp5oGsML65XmTllzz2","st_dist_04":"QP52VQVGWHf1UOsv4p9bYORb","st_dist_05":"viH9XuI7OWdjHiJudKrNtWdd","st_dist_06":"FtiGX0ga1pvujtjpQqUfWrfI","st_dist_07":"VIzQh48k9ti89AKRogFUHVsu","st_dist_08":"TfmExApN1RLFpaxGg21ec6Aa","st_dist_09":"QdYeONNea3mxLzebr16sMvPg","st_dist_10":"WZfJF98rxjk9tCGVbziiD5Id","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AMAVT1dAMvxTeafTQZy6anWvIla6o"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":775,"st_w_id":1,"st_quantity":97,"st_dist_01":"hlCikY0hyTw1CcFiuTuq9rXC","st_dist_02":"PQEWjLVQCnOMkDSya0eY0DwR","st_dist_03":"XeeOLCvPRBcesJrvd5BohddN","st_dist_04":"CeYni4fmD5HiutXcIvmyQVsu","st_dist_05":"hGTDhup5SPQevlxK5hDF8iS5","st_dist_06":"ltigCiVCt8CSCJ73KJZeUsIg","st_dist_07":"fHjy6B6M7ld3vY67N3emWyJT","st_dist_08":"rl3hOOk7peOvUkpBmPRnWKVW","st_dist_09":"ZJ98ExXPfZCgWAptHJI6Q4vU","st_dist_10":"BAjiHpzfiowEzbM66cNCrGbg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lUO41X3aAAVk2SZNoGrcRsevaoE6nxOJy0dR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":776,"st_w_id":1,"st_quantity":11,"st_dist_01":"nNtErio2c9eZLKY5H2Hw7aIT","st_dist_02":"pOfXOU1453W9EqCgUM7R1GOY","st_dist_03":"FrRVGXRNUnb1jDWNit3v5EE8","st_dist_04":"zIs3GaPIXNkY3yu2r7mLqpaA","st_dist_05":"A2fTDwOswD5cRP5aljsNYSPN","st_dist_06":"Fn6ENxuquuE4HwUKYl7mEG6L","st_dist_07":"l3Bmpqct77Z5E7tznBRFPqWy","st_dist_08":"68kvVySPcWNe9euzvQy0ydoS","st_dist_09":"Ia2CVp6e2IBNPwckIpL3wW7U","st_dist_10":"mFaivHEVwaenfTEJfmz6wZVF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mG34siPp2McuRY38HYBXrsc2wAr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":777,"st_w_id":1,"st_quantity":65,"st_dist_01":"HVw4CmPxB5KtiKGSo3Fd1b5D","st_dist_02":"1e1U9dP6voxgiv31yw9AaSZw","st_dist_03":"K9fQ6eJyfxBDi7HOfK1JZ84C","st_dist_04":"1RDYZrowZwrAAeVh4gc62DoM","st_dist_05":"mj7mPoHe5iqDdWJ8YXNEY4UP","st_dist_06":"w3OpHrXwnrHzj4RDUZTzCCog","st_dist_07":"cxl1LLemjdWWLPHT9kOUgwVp","st_dist_08":"FuAUi4PLMfgfz3gb78Wec3NU","st_dist_09":"aJ7VstN6tzuhrNZ79VeW9zj0","st_dist_10":"UQvx3TpMOTUo608DB0CS484H","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1cRXrstiSuzf2sOBE0lQXoriginalyOQRhkvd7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":778,"st_w_id":1,"st_quantity":44,"st_dist_01":"lhr7j73kHISbIt5k5KqQzq7G","st_dist_02":"5e4CGgy1DpJyGcJrZWSe8rN2","st_dist_03":"j3Bd97q4JLQWzeNjoAe2phea","st_dist_04":"wFimMUsYJV1ztnRjzppnferA","st_dist_05":"qMgWAfCxiCOTjal1REL5MwMh","st_dist_06":"wRn7SSEB1Gwi0TDJTEvWnhrn","st_dist_07":"ANJAmBCTs5pNlcqEoXsIaPph","st_dist_08":"wtKYd5aL06Exc1wNWHr2d28x","st_dist_09":"ni2Rvg9EyPbXlBlMVgTmnY97","st_dist_10":"Zfd94rHjlu57ylrJaK3vA0Jc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IuC9kBiGbQD6mtlcNv5fOb49WSjT1D5p"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":779,"st_w_id":1,"st_quantity":41,"st_dist_01":"LP7n0fcbHvE4lr4EzZYCIGEG","st_dist_02":"aOAQfqi94GuG95TN5aEI2aVZ","st_dist_03":"c8zUruth8kDdcNSJe5HPwYER","st_dist_04":"kQ3aoJowwbQ0yJADqzpuq2br","st_dist_05":"CvydYW10BIiCBVrE51PQ300U","st_dist_06":"sCl7EMmaO7UDJft0M6DHTct7","st_dist_07":"rgI95h1iPh3c91BW5oT8f2f3","st_dist_08":"Sb66SriWPWeQaqsXqj0LPHfw","st_dist_09":"i2O1y39B8ZkiUahKctszU1OA","st_dist_10":"RVA4Wwh4QqD2igIziQB72v6V","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UV9cTDf1qAzqSsiCyNjbizNUc30f2HYrP8wjljx3pxJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":780,"st_w_id":1,"st_quantity":17,"st_dist_01":"NZgrBZIjn6opaboGENygQVbj","st_dist_02":"y4F5hphTBRy8RpvyYxc3UsX3","st_dist_03":"z6W8cYPqNhCeQCuzPknNXWBY","st_dist_04":"mL75CXacYKKwCNKdh5C5gTGz","st_dist_05":"8dVUBQQCViK4PWAPftU4aTge","st_dist_06":"HEdhHRl0P0ggSVqsmFWz8U08","st_dist_07":"tks1ktgwzi8PYXK6W1vVH7Wr","st_dist_08":"HMd6ZEJ729dtbi7EZvrwIFNx","st_dist_09":"dtzO7lSmAtNDNghcwevTFGxW","st_dist_10":"xYnPV70HBxgNlc2SfWBQ3Hu9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BriStGk5UIRZTWKRJWNidkKSj6jgLj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":781,"st_w_id":1,"st_quantity":66,"st_dist_01":"C6NBL4HCYpQ1EvXbEJiMdBlO","st_dist_02":"HzVSyStHETxqQaOFfRRL2wXj","st_dist_03":"LtGH8CP6iepUH1dkd33EQguP","st_dist_04":"8GXd3riBahAf5HU65SzNWqeB","st_dist_05":"DdTSKHqSLNJ2x93yHOZ5x2OG","st_dist_06":"uivYpRIIclAbgV10tCbuOs7E","st_dist_07":"3Kdj8nD52t54a4wakVQeqxtF","st_dist_08":"nAhcco6bnFIAllFyqB8FAPIK","st_dist_09":"3BseYN7hQQhr1XY0O0dLI9Lz","st_dist_10":"XEqXCKC7opojgLZ8asQBT9FR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RvMj5iVbQ5pb6dPVUAbVYOczFPwJv3RA0RfNdLw1zc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":782,"st_w_id":1,"st_quantity":34,"st_dist_01":"CPk4DAGJOm4cIaTbpI6c0Xyk","st_dist_02":"Kw657EvciS8JLgXZaw6R8yi2","st_dist_03":"scPgUCUuowqpqg7Gf1fqZeWC","st_dist_04":"mmdQoru0VWRypSNxa9APWO80","st_dist_05":"5E6YtdgbakeqqzkDDdM9e4ED","st_dist_06":"IcU3O3HPybt7FrsZ0uma7J1J","st_dist_07":"FCT0sY07tuChmGSsAgr7QOr8","st_dist_08":"Srvvfw9QOBWq5jW61uNRiH06","st_dist_09":"SqVYy0UN9wZKIQ05TN6loxOd","st_dist_10":"9Bd4RVtbP7GCRDnsaoj1mJlh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xM8RRjWx4suOymxpspwpWQKM5X4dl7dXcSadR0xApsPtfh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":783,"st_w_id":1,"st_quantity":41,"st_dist_01":"PmIWREwJWoAPrXTCIgT3TGWq","st_dist_02":"srlq6JjDhYn6BNmeRb02SzWG","st_dist_03":"81Fl26vdhXJyjssA1SjAsg7C","st_dist_04":"3YOk6FpWrNO5oyVN7cy6nV2Y","st_dist_05":"PFIo1F9Bibiod523lboQJ2uV","st_dist_06":"fdlRBb9UBJsgWWXEfD9dt0JY","st_dist_07":"w9JEEwuv4Gnbu8Pn4SWSRg7f","st_dist_08":"4fseYiMZiVR22K28z1KA3y56","st_dist_09":"Bnhutbybiy5lPCLpKzeMB0Ho","st_dist_10":"C2J9BEeQcbNraeUd89vUpykl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QPoMjaefuqi05rag5S74vpVqyXZJVMQ93sV52e"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":784,"st_w_id":1,"st_quantity":19,"st_dist_01":"b7sA4yqFepVdxy9Pj9VHmd9w","st_dist_02":"AVGWJKGq1etSA6rOnqtWprrL","st_dist_03":"QxZIqU2rv86R2mVo3dNr6cdq","st_dist_04":"wVStZ2lEjrMDHEEI9tks50uZ","st_dist_05":"L1zfbr37veq0VnOm7Ow31Tgm","st_dist_06":"E5wygxLYNAgGemMDP2NOHHo2","st_dist_07":"uziDPAQ6ZtrQdYojgPVMhnpL","st_dist_08":"uG9D4UFipojYaokLNaGb5WvM","st_dist_09":"BerktGMXPwpHqKqP882fd5az","st_dist_10":"WOEU4RzrQzNMfo6GHs7y9fO2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7vCUDVxYljeVX0LuqNkavQsbXN5IXmLUan5D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":785,"st_w_id":1,"st_quantity":97,"st_dist_01":"rBNudpOaYrmmNDhsddflNZI5","st_dist_02":"iz1uSEjsVjIgxD9LQbkFxlZ0","st_dist_03":"kXxg4U4d0CsviVvcvrgKImm1","st_dist_04":"NSSpNvJjyJdi5SGYY4alXxmm","st_dist_05":"mAtSh2vyzuFyOEh6ObENHptL","st_dist_06":"iquv9Fg5cnq1mBszJgV5qDuN","st_dist_07":"QKnWu7uK755K36Vi4RUGT6bt","st_dist_08":"BAxobcikR8DD69Zw2AYk2wf0","st_dist_09":"1d7uB2sKj4DBcai4WQHuuEQg","st_dist_10":"DqQf9lFOXYv9TcPu72QQRnQT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cXhI0XLHAh9jpgEQsvf4pxkCLW9YbWyukRUbUSDqZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":786,"st_w_id":1,"st_quantity":59,"st_dist_01":"19m8oNMDwbviFDIiwT1gahnw","st_dist_02":"bOrBcPkonLDco6JU9bPZ8m71","st_dist_03":"oZegeSt6rvt3Abg3P2gyEDIe","st_dist_04":"N4eiVzkgpevajb4oXVaheZEf","st_dist_05":"RMHc0ek1IOsmpKfK2gL2tZA9","st_dist_06":"VcwwcNWYqSlY7hDfIMzSZsRj","st_dist_07":"u2v75xPtTckvUgjx997xHwP3","st_dist_08":"i3aij90rosi58edzoID7QKOE","st_dist_09":"EgqBY1v4qQdWZv9yCOWfzNXO","st_dist_10":"uGXmvphdSTSXpJCBDhvk2knE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SsicoK02hOmakFzaUSWYak0cm7ykNxmpzIdmaUGugJnU143"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":787,"st_w_id":1,"st_quantity":55,"st_dist_01":"PauehiTCyLrqgT4Gi1vA2V7V","st_dist_02":"zr8sRsac4KMeMOY9OSleOsBz","st_dist_03":"9A7hfb2SfoCNOWGC8BkLom0v","st_dist_04":"66m3xLlaujOPjfDaDyfLw2g0","st_dist_05":"USsdmU7RCJaYMFTwAq8siOsn","st_dist_06":"1nYX18P6Q1FefjdgirBNXaUb","st_dist_07":"HBIqnqmcEAALHYCPv27QcBFm","st_dist_08":"2uELE0NRDSV5tg8IePTihj45","st_dist_09":"AA0fmtpkcL6IWoBrrKwxkzTH","st_dist_10":"Ml8kvGnpN80cBd1Jf7SHdPNY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IefGXJl2rCz2Fq3oI8j1LnzOREr0y5t7GMvu7KQ0GI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":788,"st_w_id":1,"st_quantity":27,"st_dist_01":"1ubocHMLqtDOAEdkpr6jFFS2","st_dist_02":"uPsrZRwIWZ6N4SftmmgQ1aQv","st_dist_03":"sCrCfZGkY8JCmtAGd8NV4Wss","st_dist_04":"yY6WA7Eck6qaPQrp4JWYu0MT","st_dist_05":"0juy46ddMTqLpynefDQSbIkx","st_dist_06":"eniXVbU2cZMf1LxH0XUjwfRK","st_dist_07":"FYeme4WTLRoI7LZPBnA6NddT","st_dist_08":"HU9dOfvfyaf09AFTUb564OhS","st_dist_09":"gGrEl8tBGLfcpuFo64FTR5sA","st_dist_10":"1al6vgBeW68jAhEU8Fl7cvl2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CGyatQNUXumt9UXJfNwga01WqL2WQSAXKIY9Lsmc6hhwTTyyd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":789,"st_w_id":1,"st_quantity":96,"st_dist_01":"sVTJpUYkkIKWr6DKMGrtaCra","st_dist_02":"64IICiHZw48Csc6weu22gPBI","st_dist_03":"iCp6WJklpJUmt7AXCzAQK3OW","st_dist_04":"DZZzdSH49O7kb1h4CvmSQTXd","st_dist_05":"frhwCN6Vl3XdxRfqb7dNeDx9","st_dist_06":"MWRqQDvCJgNi7PYPlnEe35wX","st_dist_07":"gO4P8S6j7WXpEYVLoAPfgXFw","st_dist_08":"8V3CQeR9uuyD7PjzcNqBSmus","st_dist_09":"q4lBywrVD62E5uDblj2R9LOo","st_dist_10":"TDYXRowJLxhTaujPIpIYPrOL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rvAtFPeIliNHAnQLrV66qezDuk56kR0XGLKlxHyltZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":790,"st_w_id":1,"st_quantity":37,"st_dist_01":"J4YiLMXkoADNdTZfOui6MqJl","st_dist_02":"3X5wu6y4NVDH5TbL14Z2r9V9","st_dist_03":"CCrQkbeeSKepKydQI1eyyxtd","st_dist_04":"5SN2HxjuLgGl0tZzMrxvPXEK","st_dist_05":"zyHvlZq9Si9zNBfiikik8Vtf","st_dist_06":"GDzkODItUTh8sxIEu9LdJCPi","st_dist_07":"UmWajdphLSwNzvVKFOxW0y4y","st_dist_08":"Z6pnA4uFU6XpmuhK9x75AUIM","st_dist_09":"a19QcVyYDDogqzHP5wzlIfb9","st_dist_10":"QYUCEYbuFeXgHZIJ3grUXWdN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TEcfzhkNYNHJ9wrgiJb3w4GBNuGQy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":791,"st_w_id":1,"st_quantity":53,"st_dist_01":"MyR9G994fOmbVpsLUFL8pxim","st_dist_02":"z1phrVMcEUvI5Of4aY3ZdHAp","st_dist_03":"AuDV3MIhQyPExqYRRdnyTtuS","st_dist_04":"4BI7TpMaffg3dUlkFq9ZkSJr","st_dist_05":"gJQYY59NY7MR0nRlSh1r3dKA","st_dist_06":"GmOWXCj0RavZfMHNx6mxSduL","st_dist_07":"7fq6FoZGU23sPQx8JWa39hZ7","st_dist_08":"lmPLKyVlyodHESsGLZK5QHbO","st_dist_09":"myMjAPA4bXKvnyz4RrgWt5cW","st_dist_10":"IXYGgIuUm1nb9LDWnTuyvstU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SuhzWbkebPAvKuD7ozojnJxRfZXRa62iLJpxr26Nfy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":792,"st_w_id":1,"st_quantity":58,"st_dist_01":"j2HPyCP00mxbKw4IOUJEWVSt","st_dist_02":"4DA0P8MNPEH3WU21WMsfKDtG","st_dist_03":"ridLVKUSaIJySFbIesH3W0vz","st_dist_04":"ea3EiPgHocaMbbR3ZrQVlNw5","st_dist_05":"8C0UvRwu1dKSzLPmGMb3uwdz","st_dist_06":"PyyTlEWxAcJoknXniftlWLlB","st_dist_07":"xWG4V3Teii382CaLVYNWPcOj","st_dist_08":"mEa9jQL0mmXMOiZHjcmNIGPP","st_dist_09":"ewir3D1Y303O7qF5feBk3yQq","st_dist_10":"6u5fwi6Pag9VjeDSXyZ7rWZN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PePyxBpfiw8nW1l9kHXt5g2Czrw1VUZvsfpe7EDgOTw5RWYnFp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":793,"st_w_id":1,"st_quantity":95,"st_dist_01":"uTYgkPN44ChRWdegzFaEcHI4","st_dist_02":"UDb23bwm2lSgmV043gyiGSzI","st_dist_03":"CCTPco5uZ4Z1kb7oOYppPrRE","st_dist_04":"ytWvv7vz1N6mdOBPDIaXqonl","st_dist_05":"26K8DpGipndYt5EQiJw4bZn5","st_dist_06":"HW7XE6arAUaby3yYQjrIWWA7","st_dist_07":"UhHxWDgv8spCIpXH0Njz1xKZ","st_dist_08":"7wjGcuTAhV9vNN25BXf6JvP2","st_dist_09":"CggAgW4kgZjRLKus0u9Fw07P","st_dist_10":"vDWNMbJ5iWPyQ69eNNIrEY3b","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yWEuHNTzsOrxWJn0EM6sIE52CvGohRJ9Qss36pT5y4meToWF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":794,"st_w_id":1,"st_quantity":94,"st_dist_01":"Txrp7MfWZmHyzbUXCZj1GutE","st_dist_02":"Txmzpgb3EnMSZp7LPaT3m3kO","st_dist_03":"5ZWvKrehGPof7Wri6u9H3Dyc","st_dist_04":"45UGWdhrC64H5Mi6dGc3bqAj","st_dist_05":"w61AcRFrKahZkseoDGXYGEqx","st_dist_06":"kRacYHqecC60p2wL84gfrr3I","st_dist_07":"9e0dznWqV5b8WcMwmkWxiZ8g","st_dist_08":"Gd8mCII0LlNnClG3iYkj0w7d","st_dist_09":"qKhF91Xbs5ARWhrXJU4qqwLI","st_dist_10":"CDmQ6QMs66KYMLLrLMAUqAX7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aaKvu5SLmu9xgzharO0LgVP96LEnxiNohbhgH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":795,"st_w_id":1,"st_quantity":95,"st_dist_01":"Rcc4iYeq1DVbQlH1sOVh948v","st_dist_02":"kWMX9M1EVzM707nc7twhSc45","st_dist_03":"mKYlt9yivqbNDYAlMLRokeVS","st_dist_04":"SW4UG4g2ynvkOyy62XSvaGJR","st_dist_05":"AQqokFVJzYFAxuZCAlQidVFx","st_dist_06":"SImscnGMUWQXkI1zbREGa7Ko","st_dist_07":"TYQvAUhQoEdXX4930IeZ98a2","st_dist_08":"woG0vgoU9tKNu7KI4YoMYuCX","st_dist_09":"hioOYosshoydMnC7Q7dmIenS","st_dist_10":"fvN0LrOiV7XYRZWrUIydHNkq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"krWYIILcgXZNkMeHPQ2uiq1jrIltNM6igLvJT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":796,"st_w_id":1,"st_quantity":35,"st_dist_01":"0rj7J0qNRMCmcIwt7lat46Py","st_dist_02":"U4nwD6dzL1RBZPsx5Buk9rjH","st_dist_03":"GYhtAV86DQ1gkWaobJGu0QEa","st_dist_04":"Y83p1Lk4sBXkD9fVpIoNDSDX","st_dist_05":"ExqpdWUzRAutN9vKftdapwEK","st_dist_06":"DOrvxxTsq3GTdnenYbE2eLDV","st_dist_07":"sTABVqNkehMoNT4TwtgIEWwC","st_dist_08":"vweZ5MKCu0HSsSeBCDV7mYS5","st_dist_09":"gbsIUHk1U1xdxRvTeqp36zg6","st_dist_10":"Cod6uRVOSbJNMVs08tRvwfWX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cMjLLKWFrG8UXBTsN29jmhEvFt3R5SX5EwkcQiKmP80"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":797,"st_w_id":1,"st_quantity":85,"st_dist_01":"0lDblR7jZxL93k7iDal86v8M","st_dist_02":"THV8yMl6Rga72wZQ1FFzW6dm","st_dist_03":"iWFVFnnRjDOf9dUp9b48OvML","st_dist_04":"U4U4iXI2bKZVmAjOL1wx7qnB","st_dist_05":"UmWyFHMQOJbdwZstWFcSjlGJ","st_dist_06":"OmL8csSQTMxQIXh9BKfx8y2r","st_dist_07":"XfJltLVqASHgCgkF3Jc71oSz","st_dist_08":"FfFvDx15wgMXOFpnN4UphPfg","st_dist_09":"filOiZJsGoZ48B7SUhO49kVK","st_dist_10":"ObKYccSnYAV9YUgooFawj1Mu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KFFqXFCxeVdUV7byMpivvunlpNPqZ3OlomTgt0wJyIgLJ6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":798,"st_w_id":1,"st_quantity":13,"st_dist_01":"rmfWLeUg2c1h3FqH4TxJ6Xyn","st_dist_02":"PxTM83lyDhIl2xB6wVLsPl1a","st_dist_03":"8bDuVHRERwRMefjjTF3ZKMRJ","st_dist_04":"RvT4kfHojmzMZJTBT2YTw9zQ","st_dist_05":"LLnS09TyjaeOXRXdrN8os4wD","st_dist_06":"C62azhRwOuNkVhq64KAHFlxw","st_dist_07":"MN8gKao3tHwDBDKzhwdBAIFp","st_dist_08":"6RndPIqkCAgWAu3ny1bsstSh","st_dist_09":"I7FfUafvoCJqTbZj9qvS0z7D","st_dist_10":"YeI7xujVWbM7fINBid2rIdIO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6exBAZfsQ5sfQd8uG7buHdMRmSChkRh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":799,"st_w_id":1,"st_quantity":46,"st_dist_01":"c3Q6KI4wrhALW2z9yYQ8882L","st_dist_02":"SCrnqNQb8XCUqEDOeDIgafm9","st_dist_03":"UIDxNWCNcgvH4k0WM21i284I","st_dist_04":"4JNo7D6WF1KwIAX2ZHRnjtky","st_dist_05":"t0IsKwLc8fFt8W0AjKzFRUlH","st_dist_06":"6txGXUiyy2XXY6tiFzZ6Ora6","st_dist_07":"dxUbA1AWIReGUMFJxGhhMxqJ","st_dist_08":"1UuXBL50XHRLR8jfmrlkbEeO","st_dist_09":"N1Gk1pvEvl9uR8MrmKIAmp0B","st_dist_10":"M86Se9TykLmii8B1D9zRzKfx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KRCozIdAdxEqzeFRNKQmqW3giY0leg4S"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":800,"st_w_id":1,"st_quantity":70,"st_dist_01":"dZtwmEPBfFinZe8ZNcFH2GZH","st_dist_02":"sIEzoAJX9kDyUjfjtNWz9Boo","st_dist_03":"TLmeAwMYGPwZV5jFmTTFtJAq","st_dist_04":"5HkAXyCNdMwKDVtWO8gmPjUu","st_dist_05":"vHUMSqI7Ftob7znbJwd0NHcG","st_dist_06":"T8lwPGDOwRv1Fme24C2PH4hr","st_dist_07":"Ul6SJe94pHd19BpBOa1dXUBp","st_dist_08":"yhIgoDq4nAFpKnozKbg3jsRp","st_dist_09":"rvHp5Z2Za40aCByqhuNVbwcM","st_dist_10":"vejONH81dEs54r9VHVUZlQ5I","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Rw885qBIB1s1vFHvbk1HFgnBHof"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":801,"st_w_id":1,"st_quantity":100,"st_dist_01":"2wSJa3F7zxJ7fsrkeeyaF2kW","st_dist_02":"2Gmg4y40xkEbbIeYGMzXelmj","st_dist_03":"OZsYxv9oWObziKEVWoiuqbrl","st_dist_04":"0zdl1V4RqMkzBFkOTaUNeoNc","st_dist_05":"LVBbvY07kXrfRome1z7zvgke","st_dist_06":"kgnwUVaqSmwEURjlDDoFwv95","st_dist_07":"SUJV3rxNEqvT2xLNOKM6PnXe","st_dist_08":"ZWsXczGuPARQGIqOYY13KOGg","st_dist_09":"kKUrTLFOXOnb3yuURxveZlo4","st_dist_10":"dhnQXNJeiRMRXB0pa5VzKCaU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ag9IHVODIOFuzmluG2zBGo2WJ1xGv1XItPgKx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":802,"st_w_id":1,"st_quantity":67,"st_dist_01":"kS05Jubu5ls3vtq35taFFstE","st_dist_02":"xcR0R59pJmZt8atxrUK76Tyt","st_dist_03":"Jaxk9oxwQCLPjZext5cNgmvV","st_dist_04":"5RSaSRf5XlI4kCKIrbqtHDCc","st_dist_05":"oqyzT8Qw3FChggqUiBvX2q2Y","st_dist_06":"4UcWuKaMO657FesYlCjvLI7B","st_dist_07":"pDHrl6m8ytGnZ8oNb6gO4wvS","st_dist_08":"byFQUgWFvUFuVzCzD9DiKnqs","st_dist_09":"vrpHu74mfcjcHMUTT18FqIaV","st_dist_10":"fPopyPAXARDxHiYARHDj3r3U","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PLS0S6WCpRiirV6z0PgHOeMkYJT3H"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":803,"st_w_id":1,"st_quantity":35,"st_dist_01":"yC4rQ0uoLXIhbfaC2psCDJHP","st_dist_02":"AhAcNifd7eyJKshnkg9PsYqH","st_dist_03":"LLLVPfU65OlO7Nsfb2vhXT5F","st_dist_04":"zIVJuboWKUBpkO1EEeRhqWib","st_dist_05":"6OE6Go4vgwfikf3cq0GVlEBw","st_dist_06":"nWrQYpP2H7jCqAwwM2nL3cEq","st_dist_07":"QotZPKhJhvpsZMms6zefbPQz","st_dist_08":"hdgN21QwlyeVqDwuvCuOle4g","st_dist_09":"TaCYnNqNcsl9Fas1wcvdSxvt","st_dist_10":"DUkAjt9v20P4a559AewxQnzW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uObV2pCosnELMJkj43J1r0TJkQbPH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":804,"st_w_id":1,"st_quantity":12,"st_dist_01":"QUkqBZxKrU5H8D3NqH8pwfOP","st_dist_02":"J0SqVrVud6gHXJCwjsXakZaR","st_dist_03":"04SgCJfjbwDx19a8rbwmucRt","st_dist_04":"sPXuFhwOmWDEQDeSTT4rb8ks","st_dist_05":"t7seDk1hzkm5HbVZEFP4bIaJ","st_dist_06":"5Mvv8ii0JGuWkWkk4IRezrLz","st_dist_07":"KgEXwT4s1tMu6gwriwQVx2Ta","st_dist_08":"VN7zjRmN9Y8iCu4FqXV2YhvV","st_dist_09":"7LncMFG3OMSxbLq2qkGfiVDR","st_dist_10":"ZtW7cQHN98aIJbIasbOfcYUh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YRvzrOjuaVJmIbD1pF9GisnUw32glE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":805,"st_w_id":1,"st_quantity":57,"st_dist_01":"Lp6NbiVMnNCWOYiPEHghZC1d","st_dist_02":"66Pqgp9MGWgI3mZbGAppNZKx","st_dist_03":"ygZX8d7auWp26TlYcP40JVE9","st_dist_04":"gde79ujlYR98f81qtZgMOLZm","st_dist_05":"z2P7OVTEIy8ZQApBJdkXsF1c","st_dist_06":"xZ0ZDGlxT0Ptm0JcVySySgem","st_dist_07":"nfy5i1vU5zgNeADyIAafYEi2","st_dist_08":"7LilsLqWKysm4QM4ig2ANdCb","st_dist_09":"ZEo44x76859vBNLWoQ5ajL4m","st_dist_10":"oUjPQ56Ebi5cHYEugh0enBBP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GQtJBpfXFgXHT6haITH17gLYp9WRaDg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":806,"st_w_id":1,"st_quantity":61,"st_dist_01":"zzt4sZse8QYHBcT0Z3bZJYfO","st_dist_02":"mhSWQkZxXy8WGRaqdo1ySskK","st_dist_03":"lg4eCtulyGK9BOVFdeTRaxJj","st_dist_04":"bjnKhNYpccS9i1lARWGmQAEl","st_dist_05":"5Xmfly7S7cSrsHx2YlpbcSSA","st_dist_06":"u3oG2XUiO3w7UA625ZoBrGVs","st_dist_07":"rOa2e3d72BJFSC2u45xgOSnj","st_dist_08":"MuHwz3LuzSgHuHlKwWc4W27v","st_dist_09":"GPFk8N5uV3Ng4b8ohQzlPdCq","st_dist_10":"ulhon0UGBgI5esGhc5qHeojm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vXQgQ94F90SCoD8PjgtLypJkynl5tBg7iYHvEIPoNI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":807,"st_w_id":1,"st_quantity":79,"st_dist_01":"XVdxEhdabxPJMUJ4DqW1xqWs","st_dist_02":"E4gFw4C236ApcL2PQz8Z413m","st_dist_03":"3X7NVhXfMZlXLhU98UjsR6Fm","st_dist_04":"1SykXqBN7pBpMWnmRblUjube","st_dist_05":"TD2EQRXFV9cO5THDQTCDT6Db","st_dist_06":"7x9apUUIjST8GxuaQJvhlOBw","st_dist_07":"9UJSQhjk0pm54ZwSBK92Wxbg","st_dist_08":"LBAtFS7Kqx6J8YTcrxIIqFkz","st_dist_09":"wP4MeksPIL7RJyv4yhNvpC85","st_dist_10":"OUh6WzSLmaVkhmzJERhv6Agt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2YKbmxRM7RZ4dBB9uZN46mFczs0BC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":808,"st_w_id":1,"st_quantity":37,"st_dist_01":"cZxztLz9rLHZ3R2nlIWeDsn5","st_dist_02":"TCz3NuteyENwedJ2JUeyf0SB","st_dist_03":"YPcronXdOQAUQ3JV04nf7daq","st_dist_04":"sSOPwxc6pADftFqBEZPSkUlf","st_dist_05":"1rMnQIpfRswgbwdGfa1fCkpq","st_dist_06":"6oNimb5vLS6JO3WzUCCYTm9N","st_dist_07":"Nn93odUw2CVBUGqXN4DI0LjF","st_dist_08":"RSML7Idqrj4hDuD9pwdiZDFt","st_dist_09":"5a8u3vorOsl5OgQ2RoxqxnEt","st_dist_10":"57sZwspf327UQuRxiHxpHhxB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5Y4Z2aLqVMkIfpoWrymHM7tyvifnLY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":809,"st_w_id":1,"st_quantity":16,"st_dist_01":"1UCwnM42ztzVmi9nRbqcaPGG","st_dist_02":"gZmd9hGRp3wtukzs7OTMzdTN","st_dist_03":"qDG7R6QCscM3gE84NUdUXlyI","st_dist_04":"7QyeNf6faSZS25YZFE47Rp9V","st_dist_05":"dbl2qacGg4fGyenvgTcKWqnZ","st_dist_06":"z4M6QN6RlQL2AZwpyNx4F4z0","st_dist_07":"yDFmtoP1xpKCsHdtKKUapBBH","st_dist_08":"M0AMJ449RXGat5WdUcyV68Tk","st_dist_09":"yO4KG1TGuQ6zRW8uBVazg6iM","st_dist_10":"RCSZsPjQh04LgStnAM3u0tFO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rgPKPjebND7Msgc7awTP5FjAwpqfuFuowGBLHLrWTVW2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":810,"st_w_id":1,"st_quantity":13,"st_dist_01":"ps5d8qCEdJUZjuqskRoVY8Hu","st_dist_02":"kWplVI429ARmoviZvGstqclj","st_dist_03":"14ABHXQyvCwFex6QIlm4stji","st_dist_04":"759s9jqlK4zw6mvbNiYV5IqC","st_dist_05":"LVTlOZ699MTwCXjQTVxIUiUZ","st_dist_06":"soIkGdBUVJkqRX7XN1raqvw3","st_dist_07":"97EGYO8x15TVlejoFV34v3tJ","st_dist_08":"4I0q3poolAfmCsqZB3UrBXpn","st_dist_09":"aZUG0CcrVkvTZumx6yeDtbRK","st_dist_10":"gId1G5E5Y14tITUBsOG7ncH8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1iqDghEElbPcjKm7J5hpxWXzy7bOtYdkLeGdQSjWZv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":811,"st_w_id":1,"st_quantity":99,"st_dist_01":"775CVDSd7jGqy7JuZlAhhkT7","st_dist_02":"rP2zif8KnfiU5q9Ldlh9CMgq","st_dist_03":"Go7imlZ5jl1G5if4BxC2g0f7","st_dist_04":"bKy25ZG2zMwCJ0YroEcPUUFa","st_dist_05":"6DPKJ9EU5chrydRmtqLbCKqj","st_dist_06":"zVsbjmLKQpxNHgSM1hY3EvBW","st_dist_07":"UXZZFAlVquuSsd07BtQv123g","st_dist_08":"Bs011t4Jv1qtfR0uPbBDkDtV","st_dist_09":"WyXNWKT6rfLGSmvKAF984Tdb","st_dist_10":"YjfnYqG6kAa6znJc79QFcLPr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VPoBnhuv6I8cYOH3Aaxuvi9uaou37"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":812,"st_w_id":1,"st_quantity":92,"st_dist_01":"AkqQHQXSjg0ubuyLTmoBP8ve","st_dist_02":"Yy0TEOV7Tzkq1nmwESdjcfXM","st_dist_03":"4bYW46EY5Lm8KsjPsebrOKT3","st_dist_04":"dOtKlTvMiYMHONncVa6d4B9T","st_dist_05":"MqX8KLdDKSPl4vEV2BpnuzCO","st_dist_06":"SkOg9uKvNyBtHn2L4oLbOQQa","st_dist_07":"kLbBDaO7Xv6Vo8hzqPiKpghk","st_dist_08":"keSPLk1335wVfd1aAsS0AdTE","st_dist_09":"fvRFhvdCfEh7XrwJHJbwq5wJ","st_dist_10":"xMsrlEvVuLcje9TnZ1V4sOyz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LifNaZdzQSl5nDr9e6S4RIiQwpxoBER"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":813,"st_w_id":1,"st_quantity":93,"st_dist_01":"jQqxkdWqUfTjvzy1lcZtTmzs","st_dist_02":"whrEEt2GjwHZrw1EWuxUY6QL","st_dist_03":"0St168wNEDZdU5vBB54FJArN","st_dist_04":"yCmV0wgKfgwBoqApARa3Ucf5","st_dist_05":"v5owiVbWMgG5Z0utdbOEJBUu","st_dist_06":"J8cbYUAZEXELOaXMnremQwXt","st_dist_07":"kuZQqALKQCM4SPksjijUDFyS","st_dist_08":"rrjiwLcKzFo4f1uW6JChVVR4","st_dist_09":"WX9B7UTLGJsnUC8t6r57uaa7","st_dist_10":"etPTiI6IgeA79ybu4nRYrVC1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"N0jsSRuVbE0Wa0GwVIcKPPRr61GhOKfrdNk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":814,"st_w_id":1,"st_quantity":33,"st_dist_01":"9ytW5EOOnTEO0tc55XVLDT1i","st_dist_02":"xcoa2TxbWrCW3HtoGVNHlUUo","st_dist_03":"vfv8E4O9uCPNZyq13k25qvvz","st_dist_04":"nmYKYhthVSX7Sm2mT0yI7wq1","st_dist_05":"E6QWGMWu4mlETnlqKubvOiAx","st_dist_06":"VwzZ977eDFGIT6pyhfIh2JNU","st_dist_07":"DXMNOPHQOlKgUguCmE9ZXz2L","st_dist_08":"okxkgXWAAG2K5bNUdJUa0ggU","st_dist_09":"LnvQpnq67bpHOVe43XjEDiWH","st_dist_10":"x2VxJrplE2a9Swou7IryJ1qB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qR62ZujSD9nRhuZkZdLZWkoao0ns7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":815,"st_w_id":1,"st_quantity":77,"st_dist_01":"LFbrM3aky8UDTv1SQXg0oHoC","st_dist_02":"2edCZNnfzUyxt7zSc1HtZlPy","st_dist_03":"EUlG90KqsRn4h6l4sYyCt0GM","st_dist_04":"voCHSh9fL93RtnnAWC91rzOA","st_dist_05":"r34Ji1KwQSAXMCwnSmSozTnV","st_dist_06":"maqaF6nWYkyNBUwLJoTnZ9Rw","st_dist_07":"p2nQfgpdzNPUY7V8trleStIJ","st_dist_08":"Tm1pNAVFVqSSufYp84rWe0aC","st_dist_09":"t36oZAmpz1x1GREvF21oV3c5","st_dist_10":"tBlruXKF0aCvyKuLZ7H6eyON","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5A45F0oPbT6Dyoe0m7JxyM4WOhp10B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":816,"st_w_id":1,"st_quantity":80,"st_dist_01":"MKiP8ieJ6n43oqkOPszeoOWA","st_dist_02":"UC1JqMHIFAfihBDNBFonnoOO","st_dist_03":"tEuJs1q3aJxq1pVL9CCmh4QR","st_dist_04":"8TRYRtcf61R0hUmoLIURw9VV","st_dist_05":"BWExQDs9CxYi2KZDikQEU9Dk","st_dist_06":"YiJVTWf6Jnc45eNNtmY7AvGh","st_dist_07":"bxddkulCIt2krHvLP7P1xTyG","st_dist_08":"WMIPnIzJft4cmWTmVkdO5Wt3","st_dist_09":"9JVKof9X2ugadTqdtqLVpUTU","st_dist_10":"yGYRGlhDDA3kP9JHn38jIwGw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1TUr4qKqfDWsYN7I2upPMzwzpqxpIzqm839m10C6U1Fi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":817,"st_w_id":1,"st_quantity":29,"st_dist_01":"7AUe2EqWzBz7Wq33BLAfBwss","st_dist_02":"f830rdyLkNxNWuAxWKMujaO2","st_dist_03":"gChoS9mzMOJtzTH9TisY9jY7","st_dist_04":"RiATiSIUKAYW1lnAPzhFIfcl","st_dist_05":"F8SCFhjmUGXUv3LUwfEwbzYo","st_dist_06":"nv5w8KMEzyJTErKqfbAy5SiZ","st_dist_07":"qFymalFirgecLqDMP4vbGrL6","st_dist_08":"tpC8nnrNbgtRBxHmrkdaLwEk","st_dist_09":"dn14uMoTMqTpxWqJyO3pDZMW","st_dist_10":"T4yMdvH3eimJ9sw2BQkjUFCl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R08voGra4u7GCfdljvdFv0XUJcCOM1pXfA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":818,"st_w_id":1,"st_quantity":79,"st_dist_01":"l3GHvN7PsKzp4a2Izw1MFLOQ","st_dist_02":"erE2p3tMRu0uIXtw9D73W2wo","st_dist_03":"wKlPA2KqgMMgcHGjFrcekj3C","st_dist_04":"NpygDURNsSfC696gxqmB3bI7","st_dist_05":"EWiBm9nDst8mkBhWMwvQx7Hq","st_dist_06":"tCQMaJNyq4vjrsedyMGWAB6d","st_dist_07":"jQfkpb04zPNNuRwughNCJD2V","st_dist_08":"hGU7j6daIHhpW2bh3GS3s8zx","st_dist_09":"IQYC5CUxYy9FtwzjExARhzlu","st_dist_10":"OxevvVemAVt4Gzwbc0saSvgX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"C7hgbZjnHskgGvpBinkI4BwCuIv02Tdb0sQnsi2IoxpHMw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":819,"st_w_id":1,"st_quantity":28,"st_dist_01":"6M3Fax4FWoiQwYn1hobmT1vW","st_dist_02":"zbmSWBUydbse7o0OB42RQ11v","st_dist_03":"lSSENs0Oe6UUGd2UQC17OSPT","st_dist_04":"rxT2PXobPey3LjF5EdZAmAtO","st_dist_05":"rlnHwuS8sxbuYVvR51JTnLSA","st_dist_06":"VOwYSiyz9z8yNmpHE4UTDa6a","st_dist_07":"OTXpn0FkJiNixiOhd7ZnyfVx","st_dist_08":"eWY93DsJIkRjPJDpTKVFaDX2","st_dist_09":"fxI7RpUxNTNHOCmaI77c4JVO","st_dist_10":"ZFdttEJa64olf3bY2OK05Vq1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"l0gF3LBhLVnAxNocmnWMoriginalc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":820,"st_w_id":1,"st_quantity":32,"st_dist_01":"dQalU7J16anfPnUpRq7jgI4j","st_dist_02":"U2ozx3hu6QECJIm8tHaSo3vQ","st_dist_03":"lSB8oPWTyQAt2oX2TRmnSCcU","st_dist_04":"NRjf3X7933nRojoS2m0QxK9p","st_dist_05":"6YnVdzMFDPsKUnKf9ocIYj8t","st_dist_06":"wb0WVTLYa1XzkxssnhTS45tv","st_dist_07":"547dgadOvipvIq5m0zm95Hnz","st_dist_08":"XrPAS0nB4uo2CU2HkB8qKSSM","st_dist_09":"gmW8BYsSVbXvsqXIu2E6r1Fn","st_dist_10":"wuPJJeImZ1mK1PVP5WzM0wjc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pIDUfKYz708pkCpSgLoriginalfac5NVdnw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":821,"st_w_id":1,"st_quantity":82,"st_dist_01":"QEz4uKBuFmpHKg7oQlFQKeBF","st_dist_02":"2NfO2MBhWDcPwQYc3FQPfGZI","st_dist_03":"kxaGB5ZoCDU37Bi9D2PTX4cT","st_dist_04":"COcksrmWboZqM6QsghV29MQQ","st_dist_05":"AERHUomnrssxgQQ2FslFgyzp","st_dist_06":"2Tfh1pBji0qWseuWKz2wVYFs","st_dist_07":"ah0OPHUGNCikW3dlP6ErWs4V","st_dist_08":"chqSQgdJmnL9yRV19ZDoWcOJ","st_dist_09":"jHyRwSVvkURmkI0pCziy7zyQ","st_dist_10":"kjTqTTLIZBDOAH3ZZFKui4Xf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PPq0iHgFK4zd9Wp1IYpntoJ7WLVjXYcZPpPqlqjc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":822,"st_w_id":1,"st_quantity":42,"st_dist_01":"I5aWiOXwGdfknfj0wGmWLT1G","st_dist_02":"A80tXY512xnUU0ODUgHl4WAf","st_dist_03":"tjoNKAsGqqJ9ses9jjnpRQhZ","st_dist_04":"8cb3OmcTb9cxtd7AY5awwGqe","st_dist_05":"Ul9rTW50EGv0tI27ZvTl0n9A","st_dist_06":"QJBUWx5d9ZFwi9mhR7qZBFAU","st_dist_07":"R4wLz4lbjqkf4P25WFC0uDzI","st_dist_08":"03Ot57Hfzkcg5caGq0nZ7BQc","st_dist_09":"WUvi2BnHpsh4ijA4brrzLwZH","st_dist_10":"RfqZd5teWTMcfuUnZgLobSSR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nzGt7Xzxt5dE6ET7FicnZHIaUei4kzxRnv6dYf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":823,"st_w_id":1,"st_quantity":37,"st_dist_01":"gORah7XxWCgBosJT0K5FssB4","st_dist_02":"OMnsTJGuivtHmUXOXO0LC2fm","st_dist_03":"QFmT9yAQDiwzFLZNxJBJ55Kd","st_dist_04":"UTlcruWqMXsICGjWdgvMdAP7","st_dist_05":"MBwtyUPjbluf0rbwryzCTrKR","st_dist_06":"RgNDgwomR2m1lVbjU0uPURER","st_dist_07":"MBlt97Ruhl33uY67MBuV3ZWP","st_dist_08":"6eWYqFhIJj5D3zVazwmeiOwH","st_dist_09":"kZwDpXjgUrhfqNH4b3exWeAM","st_dist_10":"4ZqkRgVXLiAH3FcvOgQXcn2g","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eVJI8ScQazpsN3Wk2NIDs2FhMXHESkEt31W8W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":824,"st_w_id":1,"st_quantity":20,"st_dist_01":"iOKkocYbYjjLy8WQKQ2wpXhH","st_dist_02":"oWWgk5G0QAbNmSJ1c5z8CbEm","st_dist_03":"0LhTbg6CqkHej2fqTAbRnGUh","st_dist_04":"OtWhovagTxrPe3A5FRLCWGuD","st_dist_05":"yRrT8etV7gWF2wrNBId9jKMv","st_dist_06":"DTOhJy6HprXzibmUrd6d0jVp","st_dist_07":"skcs9lV8D43ZurUjMBYMWAAU","st_dist_08":"SPcu3pFl4it57l79TBweI8fK","st_dist_09":"ifeHoJUeuNsVjc2C7KewvcC0","st_dist_10":"IyJGR0qR4mg76ItWD8SnIeDI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ARNfm8cdxh4Al3sHEfeyrxHMmbhwElvFpooCvNSg21ADDw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":825,"st_w_id":1,"st_quantity":84,"st_dist_01":"JPiiUABTQpFE0WSGbEyGM3l3","st_dist_02":"O83FT6raILQAdQsbqtNKYdsP","st_dist_03":"9Jk1lz9bZsQQYb2dTuyXgsSA","st_dist_04":"2wZK1KveAwYeLDzVfdY81kQs","st_dist_05":"24LwiZNEILzpwvnpo2kJ3uvO","st_dist_06":"zOYfdrDb5kMgBWGqgvop7HWb","st_dist_07":"B4VhDnjKWgrEJq4m0OU9t3Mz","st_dist_08":"QtoezmHtFDsrCa0oGY1C7tUI","st_dist_09":"7i48knCZxdzqy7d3rjmozZxy","st_dist_10":"Cx0B18SW2N5Lev4TmRqLpy4l","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7wRSeH073ELGzCyjZXvgJj5Da9FmbdgbXUQOSeUJV0FHE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":826,"st_w_id":1,"st_quantity":46,"st_dist_01":"3YrhJFtCPTTr8fZ2QVG9NROS","st_dist_02":"AWu94EvhrokVOq1FFDgClFnn","st_dist_03":"lAoSzuWZFeju2z3sdxqecIG2","st_dist_04":"fijoMEUeAOt3q9iDKLAOnPlA","st_dist_05":"m8UCjGRhAh7dyRitySEMSNbi","st_dist_06":"L282rfZzoVVb8A3L5puXJEXM","st_dist_07":"kKwRc20gTyXW8gMVRfHhGmhZ","st_dist_08":"XKUzfg7FcTWyokC7AaesPLHt","st_dist_09":"5rlK4IIeSKHfZPy3ns6vSM0M","st_dist_10":"NUZyjHIwwuwSF4XMx4bBLbHK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EPFelsPvfaQe0IgJowHp6DecUBEyVbQqIAZkoXD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":827,"st_w_id":1,"st_quantity":100,"st_dist_01":"5MbYCVj6vxzUfLP8BwbJjcay","st_dist_02":"WHNOv3s1O5zLQA4MRxPUsepl","st_dist_03":"YtcmfTD0RQg9f881mhbtxxyV","st_dist_04":"444wKw6XPhbJCUaQmQ85wX7i","st_dist_05":"fEKG4lLKFU8fYMlryo1XTxwm","st_dist_06":"rdIsllDwV0boOcAAHSSjaqVL","st_dist_07":"n9XNELttm50xJV9kdShY8Jon","st_dist_08":"Hpakdh0o9AlfMfvAhHQU0WAe","st_dist_09":"FKXljUDLNWCgDttchZ9AnlRT","st_dist_10":"3R2DOhppSHTtQttHmJRlHe49","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t1XXvvoILVWK2MJVZzzRLXcb26eAt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":828,"st_w_id":1,"st_quantity":55,"st_dist_01":"9q7VQk4TBjs8Nt0vZbB84AoT","st_dist_02":"nofdKumQ4n24ji5KwME3evjs","st_dist_03":"nEyIsjRmz8XXM4RaCyLDv5Mq","st_dist_04":"Jkc2WhBJe9zyshojXq4cAmao","st_dist_05":"6xbhxYw4wzQM0e0GfWopVAZ4","st_dist_06":"iTVu6rFkY2kdcbCgChZUcK4K","st_dist_07":"PormzZhMKWqd1LYO2YEJWPSV","st_dist_08":"87TdSrXP4c5qMXSRZg6R59YN","st_dist_09":"y5zdXhGRcphElcgh9Lx3hEt9","st_dist_10":"ZaIcq4h7DN3mv3aQiXSekgdW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XCXsgjE8IYBOioGVSneQY8LIwgjmj7Vw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":829,"st_w_id":1,"st_quantity":54,"st_dist_01":"wLEF6btQMezjBmNpal0XgoB5","st_dist_02":"jK5ZxFAYZr0vSwzUXCPmYUf8","st_dist_03":"otcgqO4Q728ROey8UmnM5MVH","st_dist_04":"wGfTGOQFAl2VDYlJ3HqG6ZiX","st_dist_05":"L0jDTh0p0likJYnZZys9drEv","st_dist_06":"okd2xlOxXrMbpUhDnZT7cL6y","st_dist_07":"KAfQRkmEvJiMJ7nVZjFcAGVE","st_dist_08":"St0QsBcmYSJV2IoL2GvtCn2n","st_dist_09":"FSZUpcK4ZlaqN0YczMv6LsVO","st_dist_10":"xZRY0zcpC4yFi3bTyXoP6cQX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FK4hoNW7VtYvWDDg6Xh2mICyUSrSJDGdaffqz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":830,"st_w_id":1,"st_quantity":89,"st_dist_01":"O923sIUgx9lx1dUymtLvy8Vn","st_dist_02":"RbWW6IixaeaIEE34AZuCfsjQ","st_dist_03":"YHcDofsSZI112GQtWYH9ia1N","st_dist_04":"wV1PFrNG6rLeGoxIJNuHbFH4","st_dist_05":"SAZfsbybjwM8DvRhUu61or0a","st_dist_06":"N9bY1n5CR0BquollnB43JmGb","st_dist_07":"1tNmeTizmqBZEe0rjDBgHbYR","st_dist_08":"9qVhCrYzeQTTLGiMGwc1bBjz","st_dist_09":"P3l1yuSCikDOAYBuyfiGY99t","st_dist_10":"3q1ZvCkMYdMeiEHP9ccz7yST","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kbyx6BI8aYHDlIuwLCXeKdyiLvRYV4HFiNl80NdwB8xCKIBCB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":831,"st_w_id":1,"st_quantity":18,"st_dist_01":"rBuMr4byfDqngH8Wmtkb4L9W","st_dist_02":"U5kYgUN7N98XgnLpdZTZbFnm","st_dist_03":"7w7VrviycJkNU7yHVv6aprsp","st_dist_04":"j36pCF0Tru17e5Ac8fgPbYu3","st_dist_05":"GR1aAqyAhNoPrhBOpmtHpwoh","st_dist_06":"1epys6qJWyNKCI702UgoOSad","st_dist_07":"SxUtroZQxpsCRRxpAYFMBlVx","st_dist_08":"yD5btQKj8dQcdpnraqQT6wru","st_dist_09":"Up6bIq0m2qEcEMcMIdpxClsR","st_dist_10":"m5nhhMIkp0x114LU4jcRSiM2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"U6JgyCCkyT9damEPoaLwULu2Dlfu0DHS23"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":832,"st_w_id":1,"st_quantity":35,"st_dist_01":"XToA1ajMvxO5sdg3193CIY8r","st_dist_02":"Q6IMk6AYnYwcYtbBpRCi3tDs","st_dist_03":"NeHcn7dExfXkmnM7yh7eVPgg","st_dist_04":"Ld9cdx1c58GeAUFpsPHbhgtc","st_dist_05":"zHXT5kKt4LMLA1Vpxd7daaon","st_dist_06":"rNUnYYDuhF993ZPbIshuAItY","st_dist_07":"dCZ5CCPV4is9aAXwKLs7CmsV","st_dist_08":"VcxpVL1SBl9NuBGcR9PxaA9F","st_dist_09":"xx4lgY71FPmkdpGPXxLuvotJ","st_dist_10":"2Tx1gdjEadSC0CONn7X9bUVe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qR0A9z7l6a78ORCxNCyeCfdU2tdZ7fmOBGaqov"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":833,"st_w_id":1,"st_quantity":55,"st_dist_01":"CuEsq3X8qdVTX8Z5r2t1HwnK","st_dist_02":"1k5YkN8tcDk38k4L20TBz0Vn","st_dist_03":"ECzw55tELgE1ZMBPNVwuTDqR","st_dist_04":"aOzaRffd5J5kMoAqxobNGpB7","st_dist_05":"uFSgNweU7wBgkOMhhjA3JjD3","st_dist_06":"0n7fw2lEwoykNXdjOpIQbZyD","st_dist_07":"m6UCkNAF9V3cfMyL4Hv0nwQS","st_dist_08":"hKCAyoEubGSXiKEOPvK0VWlg","st_dist_09":"UQDYiX6Rc0q4emezuvCTnngP","st_dist_10":"jxHulM7obQXbjw4a44iheXSK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xMRoriginal0aCBG4XjD0KalbOx5TbMFEbp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":834,"st_w_id":1,"st_quantity":24,"st_dist_01":"kfAgvXm2NqMr5xNmVl1A4b6p","st_dist_02":"iP3DqdKXBypgUAy94wBz85HB","st_dist_03":"BEtBu2SbBdwoU9yvavvWklWk","st_dist_04":"PIs8AG1jZSWYvIOkkVpVOltg","st_dist_05":"g1bG9ZNaBuepvkbvMQERFGsR","st_dist_06":"P4fNeaFviKhdY2iP5JgCsQfp","st_dist_07":"Tj8hEG2JKruBR8pYOtDZlh9E","st_dist_08":"Lwt6I2G2P1tBGPdpTkk94ExX","st_dist_09":"VQAOezghkUutypMoqDJJ2hOh","st_dist_10":"2Ry38rJEJ2dDKgd1Yo8VgMOU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8FmaqSDiUNO8JeMuhCGYZac8mD44sizNz3pUEVA4D30FD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":835,"st_w_id":1,"st_quantity":26,"st_dist_01":"kdmrbZwpRT2gAK8xhixbnK6x","st_dist_02":"fb6kq1SxyOiLXlRMeLGvYHst","st_dist_03":"HqPsPNBofsvbHQuxIFPcFCbH","st_dist_04":"20o3UhO6cGmpDW6NPmXmxEAW","st_dist_05":"ApkI8hvCvJw8Vo8OqWosJKC2","st_dist_06":"R0GwcZAgsbVDRZw7IF9hm60S","st_dist_07":"d3DYmjfEPaYpbhqKRCmytem7","st_dist_08":"S1JmKHtS80e1vOi4b7NJToVD","st_dist_09":"T4gtXPbG5s5rS1b5b6RU5yvV","st_dist_10":"bdU95MUihQhWTtfCuilVPtv7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iO8pIgPBFXEv6pI27BL10oGmtfWQKM0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":836,"st_w_id":1,"st_quantity":82,"st_dist_01":"cEorvpnLN8XBSxl4OwXEUUii","st_dist_02":"ihKKqFgRdtOKSwjy5c5dwbv1","st_dist_03":"2gNu3l4rcxzUQkc3APiGSneB","st_dist_04":"qZoXHZL3qohzK5goQP21bvrC","st_dist_05":"3jqi5w7nr7giOp9MrDKf7Bit","st_dist_06":"3cvVS7lHpPqlErwr16ZbkIVk","st_dist_07":"g1Z774XHZP8C5G2ge1uq5QdK","st_dist_08":"3bSSwMrUVLgsYEdCd5NBkMXT","st_dist_09":"Gr4DYgDuzQyMfyua3UIgWZLA","st_dist_10":"0KwkqaIFyjfuu2Om0sAdVo9p","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OroppAfkBM6O5JioCdjX7JPZyRWkwr3ZMM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":837,"st_w_id":1,"st_quantity":71,"st_dist_01":"kHp3CU8o6q1zh1GOe1BRdhqU","st_dist_02":"mzwO2Qk4pHh83j12UX7nqtoq","st_dist_03":"mVaGRH4Qx1PYEpCXCbOBlHrC","st_dist_04":"eszDIFALHrElwWUV0PAdbmyo","st_dist_05":"QsJTUWz2Jkxbizke7xdzhS9l","st_dist_06":"BQIOYaUeBDrwzjz0BDwGMArJ","st_dist_07":"c4WVqHYzqwTA9hSdxRLmDlUW","st_dist_08":"GF861kalQ9mjgFb98pkaI0gj","st_dist_09":"LY2jjCUDD5SbKVDBQrfAjZta","st_dist_10":"THsqMH1tsTrpXwFFaCsPppLS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B4SVaAC1Q2yQbibAJhpHEUGQnAjT3VsIEwjqUvuL52Bu16V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":838,"st_w_id":1,"st_quantity":35,"st_dist_01":"5yRNFgaxz0WgIdHYftJNs98D","st_dist_02":"btBxtY71LLtL45lVLfKJQ2EZ","st_dist_03":"TCE3Rv0NfhKmVRItRAI12TEf","st_dist_04":"Rj1H6jNAJ9MkXO97uPEDABDo","st_dist_05":"NVmoyfuUHAM22KFlrXQGyner","st_dist_06":"QXW8eSrddKrku0OcLvr87ltm","st_dist_07":"LwOoILrDuQNDdRmvgcOC62v4","st_dist_08":"p3Y6yRoUYUEdM35IV3C04oe4","st_dist_09":"mSyL0WI81c9XL5Hy1uM8BtEb","st_dist_10":"EhGkzV1u9TgKR0u7zh0KB6Ub","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kXdzRc5mdAbW4mVSAWBcNHdVU9ygFXs7jfCyeTTS5GOuOoG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":839,"st_w_id":1,"st_quantity":26,"st_dist_01":"ccO1kCIZ1X0Y8WBkb1HZSLrE","st_dist_02":"3QC3sjhPVCTzXQnhzRN3TFlr","st_dist_03":"fh10Gw8C4hTNOX5UHxhgMRkq","st_dist_04":"JNVKHePupcRyU8FniDaT2eqb","st_dist_05":"dE73ehxsU5xAbmv9nQ4ZUg2M","st_dist_06":"sKBIywMV4htzKNZYLqmrwEfX","st_dist_07":"Igyzr2MvMc4l8AyXdg3DFfUs","st_dist_08":"9KfAnHsIZJTLBRbziHGoxSu4","st_dist_09":"QHAm2VXJ6mlGGuohoC2ohDI6","st_dist_10":"vz3XJghfsfbCJkCpY4xDIuhy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MYuCsqPzAxootT6IpD9F5vTExXO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":840,"st_w_id":1,"st_quantity":18,"st_dist_01":"tXMVXAnyEfCUPkGXkzZigNu4","st_dist_02":"gLj40U1Sadt07vm5plphKUpn","st_dist_03":"iCoG3hX0uj28FBZuSZDWeKoW","st_dist_04":"xmXSB5j2VnL5aOxCrtGDNKof","st_dist_05":"TqhzaMSOZW8IORi9YjiQ4mRa","st_dist_06":"T4dzQyYFxjZFhDBkDHD9EU7j","st_dist_07":"QIQQTUVfJa9n7T2e62SjQ3O8","st_dist_08":"mwmWGC7MAIfTpJXAp3zYxa5L","st_dist_09":"eRe1vBP7dLQ3ZlPuHidIjIro","st_dist_10":"rzBWlLcuQFn1XlVOc1Ro8zwg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9SbCcK1QZomN5r2ABP3HUknL8LioxL8MOgLbWtp9Sz6sA5pLOP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739241,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":841,"st_w_id":1,"st_quantity":35,"st_dist_01":"kodKcDzjln1LxIjjiUikR8YH","st_dist_02":"2FWsEjN59aunSR4VLrLx2Xdt","st_dist_03":"c0efF72uTMPjDQdTx62mOQPu","st_dist_04":"cePvAj9ZqdpdfIQSBMxeT7ec","st_dist_05":"UDvQM6lMecMdYLnWjGHm0c5x","st_dist_06":"xXyahX5X8tMWxXF8HhcA8wSC","st_dist_07":"L4l7OdjOmqi2Sx2k2diQ3ZXx","st_dist_08":"GmMwtjyDhnHtbpC7HAO4dgYC","st_dist_09":"d6vhGDYyXGlauyytymS265Ty","st_dist_10":"YMyzMGVtEj8Z0f50xXNiICPO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6qGZlpBgEwrlt9QQSLnQ1Y45originalJ2Jbicta"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739241,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":842,"st_w_id":1,"st_quantity":12,"st_dist_01":"L8lj7CvRS1Ps5z6jDT6cRVKS","st_dist_02":"622BlneEkrR58SX7Abr2ZkOG","st_dist_03":"1kE5kRQ3hGhWCena662rVmkB","st_dist_04":"mlYTG2Soa16QZ3Jqovl79zHU","st_dist_05":"A6kkrHvggS1BXwfpVrwRP9It","st_dist_06":"2omHIQhhIKPXdNKIZZOXAcjk","st_dist_07":"a6Y0NTa6kFahKWtvN1hPDzbH","st_dist_08":"sK4mL1n0CZXaRMQrJRruYbz4","st_dist_09":"Ml5dRzYcGUUKz8vLoG87qdBu","st_dist_10":"vG7p25uSGxWNqPff8J20tn85","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MIcX5n6bLCgGvuPSuAXdA07fPVplDW9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":843,"st_w_id":1,"st_quantity":67,"st_dist_01":"rLKVEJl4UaZeb72UCCprMuGz","st_dist_02":"ggp62HwTehrh2XHF3rYr84Uj","st_dist_03":"vlgSA7caQ28lfBker3A5xLbs","st_dist_04":"exxT6CRvGUNFDAv7WSThVZYm","st_dist_05":"CRjIjBnD3auqDRz8zDxhSUKO","st_dist_06":"449IGwDqkkMYE9JgQMPNi3HK","st_dist_07":"gROvTxQG00m8Sknr2slDYEtp","st_dist_08":"GfkRlrPmDunAU6jmxdnlNgyc","st_dist_09":"nQUykDGudCE83Bi4PYq6V5l6","st_dist_10":"JMltA6Uy5YcX5cs0BZXDNko6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9R6ycEO5tYElboriginalPH90Tfu3lGpd7VTMMN8nMtkHgL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":844,"st_w_id":1,"st_quantity":41,"st_dist_01":"74AvUIiwkN9yfXRNV9SZVZk6","st_dist_02":"VCTJ1H285zJUJkiXueR8fJFe","st_dist_03":"SkJRYIpnzMhspAaWuWCMMXWD","st_dist_04":"JKMR2Z2JKiNIwvvwrVzGCl6U","st_dist_05":"4tjItZH2NcR0y8J7rgFEGqMm","st_dist_06":"p6sfU6bMh7115ADOnAl4VaHL","st_dist_07":"8j6TozkzhhRgAJzZZaD5LmAF","st_dist_08":"l6Ih9VHaxMJ5GpJVE6lp2iDj","st_dist_09":"4JyG0j6eB4rQ5mfjInL7ZS24","st_dist_10":"GyIlgXGqpMGYehOAvP8kbrOB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lLi6GRVjlbT3LwgJaDrYJFoMVT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":845,"st_w_id":1,"st_quantity":92,"st_dist_01":"Y0lQIUzJ9LYEiUdRJYEOZbt4","st_dist_02":"BUriQQjlicEoYcJZH18Qge6p","st_dist_03":"MofHzBYPNrQqLkigqCUWrrnb","st_dist_04":"xsXroIE58Mk0mRaU3IZ1yzAu","st_dist_05":"8vfLJ8uWzGNypK7ITH1qNTsM","st_dist_06":"2qF3Lgxtrfu1Qx8jT8Wu2Ms8","st_dist_07":"balFrcZ6R0np28g3gtGBN4pU","st_dist_08":"y0CHjlwv717WolUcqtDBiEs0","st_dist_09":"JnioXOfC3cTwsu3cpErivcip","st_dist_10":"BzpLkF00mMvhZm5WmhlIlupi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ls4cU80y7xEPhi6TqYb2UDcPMRlF7xAvN0BsRH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":846,"st_w_id":1,"st_quantity":57,"st_dist_01":"ZnpU4YhncimGjwdZcvaOUXEQ","st_dist_02":"soSpdPPLpQ1VmGEE7BlXIa1q","st_dist_03":"H6IDqEz9Bo07h4urfMc6G6n1","st_dist_04":"JbzkkvEdz7JsGpCdaT7VHDeH","st_dist_05":"zU9x4U4SLLDTxJNPvq0nSknY","st_dist_06":"q2SdxBiMl0vqecReofR3HkIQ","st_dist_07":"7SiI3ACNOK9VRGHBLvBEaaeF","st_dist_08":"NDDlLMv9Rp0K1NU4hwKoxNp3","st_dist_09":"JIpxejqPAkvBE2gyUf7Giyr8","st_dist_10":"9M4t7qDbjReGfItM30qQSqW8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"I0A9oz4yHqKCdUytrFbOje7PGoriginalcyeW5s4av0YPxo9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":847,"st_w_id":1,"st_quantity":39,"st_dist_01":"vk6mSfVmWlg4ZMp8q7EdKF7U","st_dist_02":"m8r9vZK4JvnvCrcyYYKuhrwk","st_dist_03":"gy6SRIoySMVBuKFU6TZl6Zu2","st_dist_04":"4X25zS5i5EhmwUrQjC2oxrWj","st_dist_05":"zbKX6Ob1S19WBnVKZoKUwBsb","st_dist_06":"3vi9lXQJiRcJDzJGYvKxZa26","st_dist_07":"XIM2QPN7mjCA5kg8KksOObJ4","st_dist_08":"zt0f6ZfekQzHXeo0ZLyiTzhI","st_dist_09":"JgdrmsxMk6qrwcM0EMWnByOr","st_dist_10":"Njl4vhjLNjm4a5dcOfjQYt6f","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zdTu5OTQvrA2iEg1Y0rbChlkkCH8TMtMWWxspZu6fvaeL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":848,"st_w_id":1,"st_quantity":66,"st_dist_01":"52vrdhmtr3zTSCNIrKeFyDLu","st_dist_02":"8ectuYcjwzHhAEh7JsKSlsSF","st_dist_03":"hMR5V3I1GcdI5CgIFaAt11Wc","st_dist_04":"mAj41P4IcQFKZ4olAVfwTnVq","st_dist_05":"BCYEEVv40V7yUI7aZGGZ1KZ8","st_dist_06":"PLVHhowWl0oeq2M27s8DfXDw","st_dist_07":"4FTTR7TKSQOrLfe6jlEkbKv0","st_dist_08":"eaiHJTyjQt3nXarYeQgz29rp","st_dist_09":"aD0gHYIso3cogznQyp61cDQi","st_dist_10":"eoQm32ufoPiKwRotK88FKXPR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3uJ0L33x2I4A2RzW7C6VcfrS1yIaktUPkKuUWQ6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":849,"st_w_id":1,"st_quantity":33,"st_dist_01":"aBA8kqQcVKcZW0vKIJufo5CC","st_dist_02":"sqL3ISQzbp0rgMnHyRxY9YSd","st_dist_03":"1oGRAGWMDyhXkhwa1xC6rfWj","st_dist_04":"UD1J5kFUbpyCRCdNqwUD405x","st_dist_05":"DDWvQEpfoqIQO15qpzuv2g0O","st_dist_06":"qIBQrGDPGjwQuuI5shfSQDdp","st_dist_07":"kvCUBWtGJTj2l6uQis9pvp2d","st_dist_08":"Nfeww9uWy8gHUhbYRdR9fyJb","st_dist_09":"u5QDVwbrmkznqlQaRsVkOC0p","st_dist_10":"z9Rn3bxMMvcc6RR5GDA6jI60","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IygF14VAQKAemaHkDh0J6hTsrK3cwghkt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":850,"st_w_id":1,"st_quantity":74,"st_dist_01":"k7uPXihaK6TiH4CcCq1xC7WM","st_dist_02":"wXuPT86w6rSbwRLaPbMMTFzp","st_dist_03":"xpPj0G8YiIWR3aIBfrcCqBCS","st_dist_04":"Ufrr3sGZXtukOM9PRnKjmnf5","st_dist_05":"WR25QW3PLGnkUiQrZpXM8k09","st_dist_06":"B0TMkn1K5G2SStE2l0pUXHyi","st_dist_07":"wexnc3bSIfOkUDmKaWfWZhO9","st_dist_08":"qru7r7KS55GrF4Xpc12a9odd","st_dist_09":"3CBZMlJ20H1sVPN2yxUeX4xE","st_dist_10":"GLcE2i3UUtiKjy1dEeOXqWEP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SZldhHMevGpwy6B5bFGsHwoPho"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":851,"st_w_id":1,"st_quantity":56,"st_dist_01":"eHsdQBzJurxyyrGlpDSdK2yP","st_dist_02":"zRXHV06yRlds2oAKANbVfPRs","st_dist_03":"Kn1WLMQvZLt2rv2w5Qhg00b9","st_dist_04":"owEU6cE8mXWn8uKFVNjPL1FQ","st_dist_05":"DqH9f6e8VmdKN7gb1eVvj34x","st_dist_06":"xShm4lJb2BsIoIA5ZmFiqUDR","st_dist_07":"zgOPZprwkwPbJtBm8a1lJECa","st_dist_08":"FjbzLSjo4jnjauxHYiVqr3Og","st_dist_09":"2Mf1qRqU66NuPT7unTcVpZcB","st_dist_10":"MpSCI9A9OIL2eORk0FeRS49q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CVSKzX7Zn0koQOf9bNMzdUWqwPVpa7CPHLdJ9twWDajxs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":852,"st_w_id":1,"st_quantity":81,"st_dist_01":"cJK3szz85yDGvDJdemTMP9BE","st_dist_02":"aHt37TyXG1KQsQEiiQx2hvo9","st_dist_03":"CXetORmFi5qEnmDtVK77I9pL","st_dist_04":"CqrBxWW0x98dd5awZsnRaWx7","st_dist_05":"IramCbe252UtlpjieIvUzWfl","st_dist_06":"G69XRiplVtKytm3Oovt6pNIV","st_dist_07":"uGXqxVqHISk5VTyUpkdeuFvH","st_dist_08":"AVEkx6eD6MRQq3cVm85XYLMT","st_dist_09":"oIChtt0fBrhwUqEVHGXL1Rdk","st_dist_10":"u6gO6KPlGisBW93PooEWWIeB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KDQcNRME9ksCwSCDN3DS0JZshRM4pEXx6GJwjECnkAy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":853,"st_w_id":1,"st_quantity":72,"st_dist_01":"pKzyLFbkCTWBLjwfiEwmEtxn","st_dist_02":"KtdW0ov9D6YjUcLzE8HuHosR","st_dist_03":"cIaNjBZwsMkwqYmmqm7eUgmQ","st_dist_04":"EkxIm2MX8WFVgSjWaMEazWgh","st_dist_05":"RoCmZHpdwCj6RhgqJ53aEute","st_dist_06":"4n4wvPVALOLAaueTw87RU3P6","st_dist_07":"9pmMOlW3QBu2nWFvvOGUdXYR","st_dist_08":"kkytBLcQ74y7Nw36dFyjpTHF","st_dist_09":"q8HnU0n4kuqBKUWrCDI8i0PH","st_dist_10":"BAlXkgUlx67S53ir06SXzYPC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rHOHv0VxdID7rWwog9YLfvteRpZR9mR06GymKh2ozw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":854,"st_w_id":1,"st_quantity":15,"st_dist_01":"x0JZtmRmVnd0CqGq1kfiSH0r","st_dist_02":"zmOKBbhtgTTqy3YoXwunw2Hf","st_dist_03":"hiGw6G9U2RrWFj5prFUEwVYY","st_dist_04":"Ugiipf9kC6ntPRjXlYDLKM2h","st_dist_05":"5DphWrqoUYp6LlaJwiEqbleB","st_dist_06":"UIvsUiEPGNnV4YIkFHe9YOx3","st_dist_07":"deH1pXsirASnOpKbBI9rZub4","st_dist_08":"T5CiJvXYbcFfKxlo9GyNs4KP","st_dist_09":"VLAhja4GDaQ2lIuGkcGsRxm1","st_dist_10":"7iFirSZumQLqOuX6D96UEdiI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"r4KoriginalmQOLugiTuZTGbHWpmPNn61e7Cxh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":855,"st_w_id":1,"st_quantity":88,"st_dist_01":"zqOUBNvkm6fxxmu43bS0pvxD","st_dist_02":"oHr3XNG2Cn4VbY8S9a9bnyac","st_dist_03":"UkJqrooZmjbGd1edxTXbFFMn","st_dist_04":"sE8WqMpu2XPB4oNhCliLNaTz","st_dist_05":"Kfy8WUTLkIt3DD4dnJdjwmsM","st_dist_06":"AaSrP0NuoB5JzyHmspUKEWyf","st_dist_07":"T1ry4bfrsR4H7zJnLn4PASGV","st_dist_08":"tsfSyPCBzguVxiEZDFdkoZRf","st_dist_09":"A4HmdHP3a4iqXDsRIo98rm2w","st_dist_10":"3A9NEBhChwt7fe8pk8oLomkc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MdP1t6YMRHp7yPS7hFEifBI2XBLH7KJxUP49wPOub8weaUyZLi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":856,"st_w_id":1,"st_quantity":47,"st_dist_01":"ZQ9KKPJWDJfopfnLWQrHpraR","st_dist_02":"DgtNDhv6ZhNSjoZWw8UwTV2h","st_dist_03":"16AHkcuiHWlFVPdj26sX3QfX","st_dist_04":"ii2HmpUY8mgTefKW71ku2B9a","st_dist_05":"CY1cpfGfU3DjMlNCwfwN6CoM","st_dist_06":"vRNp7wAspsmBf8pfzCynD1Ae","st_dist_07":"w7DwmuG0nw4scf8zjz2CdUCs","st_dist_08":"Zoy6AnAzuuU5sVQrHXqW8CYv","st_dist_09":"G9EcjAzeY5Ttzk5JSQOO46zX","st_dist_10":"oXu1KcS703A0MIMYHxyi22Zc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SQRdGkyQY6dzV7URhew8LkBwOOh8fJErLtswRASF6eTELIWD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":857,"st_w_id":1,"st_quantity":37,"st_dist_01":"xfkVe8MJdfotCskaCog5HpKP","st_dist_02":"oezc68fnNAZhs0hBXjJdIPS9","st_dist_03":"rRjAuqAGx2nq3ZGmiZWJDJvT","st_dist_04":"tUeAn7XCMPSgGPX7Pq8ZrHK6","st_dist_05":"7ZLCW5YuzqBZ9Hh1vX3jwDs0","st_dist_06":"DHF5vy5OLq48vy6wr7u0R5xz","st_dist_07":"gQ7htLAfWXvlKvUVkfuJVzZn","st_dist_08":"XCPy52ZDjmqEnQXERFhI0deT","st_dist_09":"q6JzsRsVAvAu6NE0dXbNhUDN","st_dist_10":"lovMnLbaxABwiHPIaMaevp0A","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t2D4w1oA7CGeRba6PESmT35ZqEMtJBdmml1P8XpiKqmx723wMQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":858,"st_w_id":1,"st_quantity":38,"st_dist_01":"aui7T0G6JNZENSN8NnuPUJps","st_dist_02":"Kp85REgiEjxPyc99CcUAgWTA","st_dist_03":"OoPeQFqMOSOPxgRoM6HwfT5q","st_dist_04":"HEdHk7nsxxREqnvBLvMTLAkr","st_dist_05":"PykRmuMSbDO9hWGsiVJ26rZL","st_dist_06":"I0a8s3o7CNOoDGVT58WSXRef","st_dist_07":"9A3Lw6OYXFJP4r3cp1qudPdr","st_dist_08":"rvAXaTkmVJynEBeDFvmMM6K5","st_dist_09":"TCiupNkZcoi6oJzC8x6KWwsd","st_dist_10":"7gi40yNA5iSO2kvVWOXHcZRL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fY7smsRYZKpPkD2l9Z7zsV2rbjLHEW6mB7Lhdrclim"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":859,"st_w_id":1,"st_quantity":20,"st_dist_01":"nophFPGuKkRlLmsv7veLzgRP","st_dist_02":"fbSecjnlqZyJVOgjfRFHsivp","st_dist_03":"ARC2WrLlGBppd08l3NaPrCmD","st_dist_04":"OxXxcPxMkhNROejdyrn4D7FY","st_dist_05":"kUCujeLpIUZ0qrqbQDfMqD1D","st_dist_06":"xgxUumgm5DlhuhOf8u1xB349","st_dist_07":"EBo4aadvIiSXGUOirgwns0L0","st_dist_08":"X00Q7eum4YHbeaSzi8lK6WWz","st_dist_09":"sZNCkhqTpAmYc0YT6oagFXYE","st_dist_10":"D6qzLvm5f4QbL5xAnXzX5Vum","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kHFMaEzFgZqLTU6Bc6PuTdMWTVrG8ubd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":860,"st_w_id":1,"st_quantity":22,"st_dist_01":"bAoKhtGoJEjMM1xYujsNFiVU","st_dist_02":"fMoD9rINP39T5HIa9NdZM1pY","st_dist_03":"wWVnJM6iJEk4gNKOh1QVhJ6F","st_dist_04":"uBG6WNES3oi1OzLTB6EwWW1M","st_dist_05":"fakUbh4IsCiOrfDcZctna8jc","st_dist_06":"w91D867A56debWvRdxhCPLhC","st_dist_07":"AXfOP5dtRaRMuvZkKctQPncR","st_dist_08":"gxILhChSOofHeVparss2ReTQ","st_dist_09":"2ElSQlzF9hF1GBFJewAhKVQ9","st_dist_10":"SOg3PwQLtZnebQsIlDRo2KcX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fVRQs3NiL7wabgU2jsHPgEstelGE55MHgQ4HMAaO8GFbwmgg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":861,"st_w_id":1,"st_quantity":27,"st_dist_01":"QHsIyOLSFBTbp12cXN1gkVcB","st_dist_02":"Hy2o2wGJGKxqrm1ksQhp6oZS","st_dist_03":"M1HZE8C7tLOnMRgY1G4uLAZq","st_dist_04":"2jSFRySG8Mr9Mf5NcaLoJa3F","st_dist_05":"HFj79DPOxymOWXIXyzKDXBNz","st_dist_06":"vKB01tc9Ofh4zHyFvA451kuz","st_dist_07":"kpnMKPtbCw3GXUIH2nzurmMs","st_dist_08":"sO3THzj4vNrlN4RTcAmwesuF","st_dist_09":"DRTE8M5yMveJbnnXLqD7aEE8","st_dist_10":"AiOoubKHjNSvHd0dNoHRk47j","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Qrx8zgVDLbj4K0QdwWyvyQTtt0rkApVgnCSqH97bQb6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":862,"st_w_id":1,"st_quantity":91,"st_dist_01":"kAANb97DKGqGDX8SUzHXi6Sy","st_dist_02":"rvVNPkaqBLZEJtqqHcplgPo2","st_dist_03":"om7w1Y5Lnufu7NduLa58G8Ta","st_dist_04":"yVmqRF7fYVrymPLXfrkH1Cz3","st_dist_05":"iLU6f4RZ1U5atqDC9HkWioJC","st_dist_06":"WIXfB5rWUn3TVlCwCJ9KuUQj","st_dist_07":"bL47sY3EUKY5RKmeCDletTUC","st_dist_08":"4lwK0pbrAVoIO8XYUJli7dXl","st_dist_09":"W2SPscMNDhawUbQAfZHLxthc","st_dist_10":"uKnQ5vKicaXQ3s9HidPiviQc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ylh1ueOFvBgP5SsKZkM53z6ejn16tbCCVg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":863,"st_w_id":1,"st_quantity":76,"st_dist_01":"K0YlEjHPfkYSeljH0Pfn9vC1","st_dist_02":"PEJD1dGukk0OwAuc15YboPhb","st_dist_03":"kFWWJmmp2TavwBFcolyuLIHo","st_dist_04":"yRM0CuIxIMxTcj7HgXmdBFFz","st_dist_05":"kZ76KcHKrV4ACuMTVk3lRcEV","st_dist_06":"CGTA3Fv4GGvWIIr12SaX1qpP","st_dist_07":"Ip8D1urDzkdC4TYWCn0sO5Ds","st_dist_08":"3KMMshxNOQHu9VLJCt6DBCA7","st_dist_09":"HxFGOtxhfu2eWyIwnHqczOEB","st_dist_10":"UWwPwlZF8st4cUE6K9dIw7J1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GGS9YhdHI76JvNsAlIoqwqtPg26fd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":864,"st_w_id":1,"st_quantity":74,"st_dist_01":"NVfs5CnunljfnrVV1A8g8k9C","st_dist_02":"XRJ2XV3COTHiJFaTkp7EO58D","st_dist_03":"HFx2al5LdWcXSR9dNSFRE6XM","st_dist_04":"cn8XuRfSxragNUFV6xt6A3CY","st_dist_05":"njYwz4rqPzHwsqQiSU2rGTvU","st_dist_06":"BU9nIMWiGOppN3UxG2Nn979k","st_dist_07":"3qzceUnQ6VlDHmjW0pHncnqu","st_dist_08":"lFMWQHehlViDG8nOfQjNh4K0","st_dist_09":"Si7w93n3nuVnvoGjHBbMcAYd","st_dist_10":"mpW0gQaYNQFYXHAnmqRGuf6Q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4cuYSNiVryFUpR7FYoKVI0MqwYiQB5mKhvcmZkR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":865,"st_w_id":1,"st_quantity":95,"st_dist_01":"fqRrZ5kZ5qVQXqeA16CPlOkX","st_dist_02":"fmOpyIOhrCbQ6Atb1maXbGIg","st_dist_03":"R6UdEXdUNBdIiSw7II5kJPaP","st_dist_04":"EHbqL6nUVCNQ7sycCgIWf5vg","st_dist_05":"4rCv9GC1eDzQp8apAZODVr2O","st_dist_06":"SRko098nxB5v2DzgsDGCVGtr","st_dist_07":"07lhZU2CqG3yHxvb9OddXe2S","st_dist_08":"tfeh0NMSWSSyvCHYtcfywGer","st_dist_09":"V0mjxGaLonzUATbYUdbEFeXs","st_dist_10":"ywUv4D9HK6XYvesTup052CsY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zMrC6X5PpUAXktqOm9kWjGwC3vx6qTEvRJTq4YKMUBrZXA1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":866,"st_w_id":1,"st_quantity":81,"st_dist_01":"BHkrxxxpIbpAEBcozndV7BQV","st_dist_02":"fQqVkjk5sQoGYecVii7kIwS8","st_dist_03":"LSiYnWPCdIPOrveO27TTkLHR","st_dist_04":"vbDQdR9JoeTmgvgHd1h7Qf0C","st_dist_05":"jOSZkhCVDHG7R2ycnhndjRpt","st_dist_06":"6tO8k7y90BckhcjTCoC8qLgT","st_dist_07":"yUqeU8kNdwFoxlFqsPicImjd","st_dist_08":"V6kRT9weVV7fRBkC7ux140F2","st_dist_09":"0VWXAwbGFpdEunOoHS985nSi","st_dist_10":"V6s3hd0G0RtRWUMHsY7FZSA2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TWjUC0eUDQ9wxpvNCfQHdCOebHezV3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":867,"st_w_id":1,"st_quantity":10,"st_dist_01":"Z6XubMB2QJ9VfIQEFQOzaOwU","st_dist_02":"s1a5HIi5hybuleR3LegR7V2n","st_dist_03":"9S11XpfeToSjKtIs5eN6etY6","st_dist_04":"p1grRr4Cwv6qereLIUOFxcAc","st_dist_05":"1385546EiEVOwhJK3BmTIcXb","st_dist_06":"5cdbSEAnhW3aEcow9AreUfWR","st_dist_07":"QFR9RNTvGVKOXnSyMuko3xA3","st_dist_08":"nuZvXmpqzpmbOdChvXJrVPSW","st_dist_09":"ZV0c5tDDqTT76HscpfXRlO5w","st_dist_10":"5DGMkQeE8yNMzGzfBINJm358","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nyfDz3GO1vTa8scoriginalrBDS4gLJB3NLDR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":868,"st_w_id":1,"st_quantity":19,"st_dist_01":"ifYiMqFSbMUEbkEdyzqNP91r","st_dist_02":"4Zug3DytjxzPWGV0tbGmfkdI","st_dist_03":"4XzYxSDm51F5oUF5HsYwx8l3","st_dist_04":"5rb5Exq7qblE8ytwaJTItr6X","st_dist_05":"k3mDVedkJadtvXuHG4hlal3Z","st_dist_06":"RhxLdVIfRLBqh6leilwcydYl","st_dist_07":"WhX8B1KhOwVPu3glyOw62aFx","st_dist_08":"F1dWqKNWc0kpW1GPEWj8lWHN","st_dist_09":"aAhIvbvKKKkJHVEYhY3RfiuL","st_dist_10":"7XTwmKIqKpWNwmCW0CppgEsA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dG9Pby0XXMIROsOrMen4lvXkKt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":869,"st_w_id":1,"st_quantity":48,"st_dist_01":"4SVFNLtuLijHZZEJ2mD4mFuE","st_dist_02":"fzNeWFljVTBWY6RVRAzXnwci","st_dist_03":"ZBSAtzbBwABvVWWSgNqso10U","st_dist_04":"UAn8N4x37YIgWUuj4I4cXVwq","st_dist_05":"LEaMQm1ZYZ2mBZ4WXvNZH8bf","st_dist_06":"NoSDtEhctuHE81GP92y4E5Hr","st_dist_07":"4IijcsQVpIi5Ygl3nEuq7ifJ","st_dist_08":"5KQJY1X4N3mxNUZuhatnqQ8T","st_dist_09":"nP9dI9EYNRF3ekVyQyTwyxlU","st_dist_10":"wXPqGJkxMFY6MXB42llxIzKW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HPu6Fdz004wQQqzxR98k5z0qYT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":870,"st_w_id":1,"st_quantity":63,"st_dist_01":"zvZJnuKbvvPzgu8MzsTyJQ9i","st_dist_02":"XnJBktew4zSQBPorpktePeb4","st_dist_03":"4S2f1cN3ycRKBwi2Cv8UcMqp","st_dist_04":"NxhPt04Tz58rOgAnF9mXmEzd","st_dist_05":"20FOQwMHNqISQBsXHYdtwbgB","st_dist_06":"Zl7bpHRNoftjzum3T1ODUIOE","st_dist_07":"Wmmsl79rNMmvHo7KW2umQtpp","st_dist_08":"8BTd4wC6lzOzUUQa0AjQqkcp","st_dist_09":"2PoFLT68397El23BATHu5SkQ","st_dist_10":"pwRaxhvllWyBJFwM3yxiCG7o","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3M6EtpoV9OwFQ7lqzZBBNE3VQTuWPTptKcMGWg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":871,"st_w_id":1,"st_quantity":49,"st_dist_01":"LLCTUBtWq8aTPIoqQBqw8cm9","st_dist_02":"zqTcMFdvu80eJl0AhNpltKBU","st_dist_03":"eCvgcjOaFFerJ1C8r39djYWc","st_dist_04":"lNyx7pNuezEc4ku9jrYUjkXL","st_dist_05":"USHwzAZKbdBg8AUIkbtkXflm","st_dist_06":"ngusgf804QJZc7jICUzi9D3l","st_dist_07":"KS6LyEvyCubTUmBsuZGvLNT2","st_dist_08":"7JL6FbZYJH25brDDFzlX2gcE","st_dist_09":"f1pQl4E9uCpGk2Bt5hkhLR0P","st_dist_10":"zBA8vz95my1unmDeFmapaUhp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PxblJR1wWIujhnXsxBRQV8jIR04kZXEby"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":872,"st_w_id":1,"st_quantity":97,"st_dist_01":"Y0KAMkJslARyRYYhOwyTMbn4","st_dist_02":"X68LIFuSqHZiNBGynwXEnthm","st_dist_03":"5EXYGTdhQEIDHGgWkTRnnirS","st_dist_04":"YxjJZjyaxphMj7ZxOPbj2Z7e","st_dist_05":"5XjgciL0sDoU9UljqdJpfkqY","st_dist_06":"QlsKEsLEDSA890VgU19MF4lR","st_dist_07":"wBjI3i1f5cfPvAdq06XG7kI3","st_dist_08":"6QmTBCKdc9ghFeGAtMTtPlAA","st_dist_09":"f3QVJBO4roYho3J7xPaj75f2","st_dist_10":"jQR2gZ2DgLJLOSBhyvZmiuV9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FMrXCBVmXcI9Hq6lWmber4OIuHnK8yBSj6RUyD40OXYcz802Pe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":873,"st_w_id":1,"st_quantity":67,"st_dist_01":"bkhYT3YRRMiTp4t4mlfSA0H7","st_dist_02":"ckANVzz1GrEUrdot8g2SHtWg","st_dist_03":"na9tDhDOk4NsotBhTG6i9Z0v","st_dist_04":"7btNSs7xpD3hopH457evKAVy","st_dist_05":"jmLbz1rn7cqHDQs8me8XTqF3","st_dist_06":"tuCLfhe5Q5EwYm7tg0IISof1","st_dist_07":"u3XnaqEqzSX9nwbYu2ageM9L","st_dist_08":"oHfZGyc6bWVBHlq9cPtvPQpy","st_dist_09":"N57SiQTWvE8ApMRASpGjui4f","st_dist_10":"Zsq6lN7usnIzpon0hGwdULzO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SVrHWWYOdlpaJMUUqEojO7UmhbWoONI1BKJEAnqUfBk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":874,"st_w_id":1,"st_quantity":61,"st_dist_01":"dvZI1xWNHqPUBK87M79eadUs","st_dist_02":"TaffHFne605MEkOAJPh8ABX5","st_dist_03":"keKRYlhzlmSfK4ZRdoY3ogxh","st_dist_04":"8Fci0pRS5cG2wRSssrsOnEb8","st_dist_05":"NPUvZFhd0PdJxWUU8ZZkIqUL","st_dist_06":"7tsBAKMKDENBw6i07g2vzilw","st_dist_07":"SAsNa8bFlAhOiPlXgK9EdVxs","st_dist_08":"rOIk61LrLeTgZUmUK9wsVyj6","st_dist_09":"iTJLn8E4O2p0DVD9VoUpOgUv","st_dist_10":"KOtOHWWwHJqr7YfOegjc0AO3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"A18zbWZ2046drXtkvbRPBfe09i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":875,"st_w_id":1,"st_quantity":32,"st_dist_01":"Mb3lNmo9O7JjvIzeSoBvVPzZ","st_dist_02":"oVNlL2Jkjy2E2nUxaU57apKb","st_dist_03":"6lRHilOKD8gn622DJ5vUOof9","st_dist_04":"lJiEGNKwatTl7UyteXYNzVqc","st_dist_05":"DZMxh1g0HRjfMZeQBqjqJxjI","st_dist_06":"tAstVa6KCwv71oogXBcAIniX","st_dist_07":"v8dvoXFM0IIxWVuvm6icgXYZ","st_dist_08":"U1D7Zo19TfKacfvEeZXvFiiy","st_dist_09":"MR4vCoeuPKrJVtFNpO1F4YMd","st_dist_10":"BeY9Ee9UHjmYPgVJXRa30jhd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CocuhAAcqZFm6uESVwOnW5lJWafrcaY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":876,"st_w_id":1,"st_quantity":15,"st_dist_01":"aVKGXgBK6TrsZGfrSwHhEGS6","st_dist_02":"tGjYOKr1Fq0ZAnis8XzCtNr1","st_dist_03":"DxeIoefW36tV3bxLCHF92DSj","st_dist_04":"76N9dAna17786FIJW7MdLk5a","st_dist_05":"F9MItc8hdi5AxmjNGwv6zyjp","st_dist_06":"HiGldEFbR7VH5XniPxdygd2w","st_dist_07":"V7vumb3B3rbOatuKMrontczJ","st_dist_08":"drgLsRvgKe3e9dfbre9E0Rjk","st_dist_09":"zQw5Ky7juT82g5fQY5njSuKh","st_dist_10":"HgrNFgzwT1HDl68L6GXCKT4Q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IIYJ34zq42knesysBtFSoriginaliLCp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":877,"st_w_id":1,"st_quantity":74,"st_dist_01":"TXV5n0ehmCfl1cHQvgWbunew","st_dist_02":"Sy1JTd9dDm3oRMXY4O6czveP","st_dist_03":"IhK8AhEQy9xoKkMqwha6yABj","st_dist_04":"dihjQLoAhdU3stDcTRT5YKn3","st_dist_05":"VssHIWTpydfBuFWvJkTP2Z9w","st_dist_06":"Cfgpzw8M5rOUGLEm5kAFSA7l","st_dist_07":"iv9EUnhhXd8pWxlnd8333crY","st_dist_08":"icuc9UQrBKlrHuTnVOe1iYTP","st_dist_09":"oy0OOaGBOWki5pWrWhlvkBdJ","st_dist_10":"8svPDleCxbjocda81cqWR76k","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5OO7lSneIAIWdX1h7MkHnDAU1apBKU0hsLzUrLQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":878,"st_w_id":1,"st_quantity":36,"st_dist_01":"87eRlMfRfvGoIr0yP6bHLiLb","st_dist_02":"Q2Jilr1TZdPnzLOZOOezmxf6","st_dist_03":"FfSneAOTF8XWg7ucQ35Zc0h6","st_dist_04":"crIvuetDP1UaqXm8MVQKbLjm","st_dist_05":"NAwsgg4ROBaPSdQadZCSPpzF","st_dist_06":"lcLPVo15yVZ2DnJh8cfoE1hk","st_dist_07":"0e8Zx1jL2RlMcyAhJI10q0lx","st_dist_08":"NF72jD75YMvZm2vh1y4LuV4E","st_dist_09":"SKCIBsFAna1W9To7kkL5WWBl","st_dist_10":"1L3MIs3ZEv0lrYyD55wCuOw3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QsO65WmCyVyOhr8C4Tfn1WyQjbczjZpWZyc3oVidHcHYapEir"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":879,"st_w_id":1,"st_quantity":35,"st_dist_01":"15keh7Nfc1hdabLmo8gk8UyB","st_dist_02":"UuISjhCYertEbBldjPQpFA0v","st_dist_03":"tcSWOOEI8Pg1oPJm1bORvwZ4","st_dist_04":"7iPhoPYPnmtcYFjFNqVJFPdK","st_dist_05":"lRVPsyKYbl497HUFBKKUu4p4","st_dist_06":"TbV1vFHHj3BN28lXwj8mHpWM","st_dist_07":"fhLUSZVc52K6kJwLSIlZWQC9","st_dist_08":"WUI3sWe1TwrsDGqdpKz04Feb","st_dist_09":"jo7EjNLCqmOOE6iJjifPGh0z","st_dist_10":"YDPNGKATgoY35DYSu7U31VVm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GnOvrQKrvL7QUuG8FiFz54eaBJAFV6jgFSMpZwVd9bL3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":880,"st_w_id":1,"st_quantity":76,"st_dist_01":"baYb6q54RsUbsxa9ag3NIzYv","st_dist_02":"gHWARzsUgaY2OTHec88PwNmv","st_dist_03":"BQvFDIy7MIeqqJSiEVhZLebd","st_dist_04":"DFWM3FIcKj1lr0OpV7p9vzAc","st_dist_05":"dliYrru8spueK6KvHXNt9Jgw","st_dist_06":"PaSiVYJ5dE0jmZWBhOuJJ1BE","st_dist_07":"J7W08EpRrMsRpkz7SQJnuhC1","st_dist_08":"JNg0IHViNL0974eoJTRDyqiJ","st_dist_09":"a6lxbiKOrlYVeNKjUWF9c86G","st_dist_10":"qjLUvNyfLK3IcGof5yA8f34Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ht33gkMDZDXCCbdhXCkGiRJRBFFTJYH8L7PyUNW5h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":881,"st_w_id":1,"st_quantity":95,"st_dist_01":"cddDWFTrzzEWV8MQd4VLpOp9","st_dist_02":"FNEyf1uTLyy57plmDIhbf0w2","st_dist_03":"2tWgt6r1qPuag916Y9PODuO8","st_dist_04":"7vkFiR819qcTvnMIwAt5MCm9","st_dist_05":"DbdDR05hxRzNf5zw0nroSgPy","st_dist_06":"Dg91oQX3wOzuKwyx7AZYp0wN","st_dist_07":"COG8NBReyqfL6B2dwFN4wdvJ","st_dist_08":"Sm4KQpYlF0wyFHAkJGcV94Mc","st_dist_09":"4Jakd46NorCH1uhERoaHhlOj","st_dist_10":"Nwfa48dk87ccRgukr6XL4lIg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"frH52Lv4jOpIGGfnPuS8jsTQ64FjOfp3voR2KJVPT0AofKa3O"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":882,"st_w_id":1,"st_quantity":17,"st_dist_01":"Ig3YAvt7ehQ4JjcBKrWD5zzB","st_dist_02":"isuf3mjQorE9aTurcDGpjlmH","st_dist_03":"dbQfAtEob2bQ8dvPofH2Q54E","st_dist_04":"G5KK7AhXJIxnKWPyX0KHnDaF","st_dist_05":"vyTVulJLYAsQBlnPyIhz18Zh","st_dist_06":"fxnnrYS3aIoDX7i4zuPn69CN","st_dist_07":"aUOXF0Ah2WNeOfKQ8jLkEJBx","st_dist_08":"azArUsKKxUbcBQITRxRy1KjM","st_dist_09":"3coOHL5BcEAcmgOISn7hWJ4b","st_dist_10":"3d60rCTB358MU70rOPTKV06j","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AAfGhDe64hpf3MPmDe9aurVR1xisonHmRaYhpGVVjdtIZgya"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":883,"st_w_id":1,"st_quantity":65,"st_dist_01":"IdIM5evm7jCqNNZEgFggQNV0","st_dist_02":"nmybIIdbcdScAXVAopL7MiVe","st_dist_03":"SSzZqnzPC6NGcvSOgi2nWd7J","st_dist_04":"L5zpHuoHplZU2S11yYCTiZ6R","st_dist_05":"dbD33DJFKCv8tvww9n3J8kD7","st_dist_06":"O8tJZkvJDBiN5wHEBqoc1PNe","st_dist_07":"o7Wbrop6EBnh5pjmgaysJiID","st_dist_08":"WUssW1wgFDGntWM7cnCpR9jk","st_dist_09":"H79Y3G7uOLzk9Y7snpg0TakC","st_dist_10":"S8OtHwOcUUBt7rxXHoDnNK20","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ilVPXQEyuiXfWKBNT2jgJyDwgGH4WiI7lzMku7mD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":884,"st_w_id":1,"st_quantity":37,"st_dist_01":"00t1XIXOTsy7XcbWYHlvjbWO","st_dist_02":"vCVunfWASteXT1BNL5a1ra3T","st_dist_03":"lCedYhmleEdy2nSRAeqoV3No","st_dist_04":"ZEchYtN6KqjKJVrZfpAhYP5W","st_dist_05":"2pVgYmx2obI1CTs8BPz7ePbJ","st_dist_06":"kcoyLAvsdT5SUFKWiXUU9wro","st_dist_07":"Z6cKv3IHpW5552fhrWhmXyBw","st_dist_08":"GTQ7m2ZWQe32oqyklu2R3Hww","st_dist_09":"tWJu9ZZzLlQeyxalhCja4TcL","st_dist_10":"mfAiuIstOCaidstFGZH2NpVO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MxZsSskDq3TffgylCw1Badbf761tnNj6dlFRFT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":885,"st_w_id":1,"st_quantity":58,"st_dist_01":"886eLyxSQxpJE5sfpEcrNkRi","st_dist_02":"uCNzZmDvkrrVoeIjk7DoXT35","st_dist_03":"fIRdpf1e0MutiCxmfG8XK097","st_dist_04":"p3GruQZnyid1RDXSsbNNffRZ","st_dist_05":"olyahstYVYBB38TQwStGB6TA","st_dist_06":"iLG6vOznbmhDGVlgfmqeZsPZ","st_dist_07":"RQcEa5KxLkEiRbIuulyTl6cq","st_dist_08":"ygz7azboC4GCOE8J7gIOHs2k","st_dist_09":"EmCNHOBEliv5tCwGAIi52EOy","st_dist_10":"XRnASTftft5ykAXFMG0Y7cr5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ctrEUahsFRWXbxwdAEXzXe0DUt6CRUYwmoP7rzwdQat49qGF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":886,"st_w_id":1,"st_quantity":41,"st_dist_01":"hWP2qHAMxfZDhibeEPIf5PL3","st_dist_02":"iM9Mty9y6dtEntSDoSEVTwZO","st_dist_03":"YdRfbtrS8Y5L1lnpANF8iSCY","st_dist_04":"fMLU7sFWnOV9gSTWyjjv83hq","st_dist_05":"T8S5l00RaNdXwT4D3dAQ2LL8","st_dist_06":"pGC7EHVFgaZZt5DObyq4nawI","st_dist_07":"7q3iAjCDLt4FULgsFm4ITq55","st_dist_08":"N4w1cjs5w1Jpw56hyVRHWVVy","st_dist_09":"SLVeeMvHxhgAfKy1J4QmXLKJ","st_dist_10":"yUhiCGx4RTkjLSE4f5yNJTKk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Qi95mNNfl01yjRfUtjkm0mXa7AG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":887,"st_w_id":1,"st_quantity":27,"st_dist_01":"LhJuraAeMv91fczISFXWvsyf","st_dist_02":"DH932NbT07gxSlVVHEIq2lya","st_dist_03":"93gWxqOInLc3UqIFeD4W0nig","st_dist_04":"gAjujsAN1D2x9vAIuIkb3p2E","st_dist_05":"cARF9Z9YM2B6VHgv79Gd484L","st_dist_06":"DYu3lXG7fDQKgD5fdU3UTs9E","st_dist_07":"pclazb44lH5aat4TeFikLUxF","st_dist_08":"CkGL6bhz0KVfDQLeXvqTwiwn","st_dist_09":"PzymoHk3dLYC2Ue9p6K3d9hH","st_dist_10":"zxnXvUVaTjHcX0N5xcWJmatj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1uxQ1AY77xl9WKs6ZSQQVLDZTsB1x7tTF52"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":888,"st_w_id":1,"st_quantity":85,"st_dist_01":"9uhBTLYZXmCQUh9Z5paEYKX6","st_dist_02":"dbeDPTTjOivsaDg5ONXzUdjn","st_dist_03":"kLekWdItkfczU80Rf4EcS24H","st_dist_04":"YFlKMtlmcLuN9Az0Nu7JXkmy","st_dist_05":"pmBaRyDcSPddxgrUvf3vTMCe","st_dist_06":"HNpa8q5pOwiqjGROkACg2Gb8","st_dist_07":"OFMDj2oeln42hcv4ZiU3GbS0","st_dist_08":"DJslVSjoSQ7j6EDwWXQdg7x8","st_dist_09":"WA1h2sIhV92FRtfLXKWRa9M9","st_dist_10":"Q7TlcZN6kxPvM54KDDNQHTq8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"H0bYK1vZPZf88v8szxRCRdGU19nX89WYsPGs3h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":889,"st_w_id":1,"st_quantity":92,"st_dist_01":"7Xdwr1bdpmz3TbJAA4rBH2kg","st_dist_02":"9hUmbGesFZHKCgOaWCOoVIs9","st_dist_03":"bziBTtprD5xzeYiWhGf2GFZ2","st_dist_04":"CwhNxVnGBPmrMloGCLZvtwe2","st_dist_05":"1XU5tjNkaLfQxLyWvn0uIYhb","st_dist_06":"ZZb7jPqdL3mHsL09O8nAF99T","st_dist_07":"kn8YEYOh4zwofWlcuoGJjz2A","st_dist_08":"f1gMeDs8HkEhMOQB03ZXsB5l","st_dist_09":"1aoX8NwkS84JOr0IUc1tUA72","st_dist_10":"DFLwb2pF2VyVN09YHaovxFqT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9i0mse5XG2ptrlxx76IbzRh7ymsLEd1zE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":890,"st_w_id":1,"st_quantity":98,"st_dist_01":"dmqkiauGUFJfJ215bm2s8QWB","st_dist_02":"MIdrHsJQ30S0wAJJU9kjw0TW","st_dist_03":"feOUR150NSLYzUDozpfkfa3Z","st_dist_04":"eHIOOQGhrEMiNMlLMp6pWKwk","st_dist_05":"MeQixn42YKzoyqEKtOaKGM44","st_dist_06":"sct7dSDNkw4udWf8B4cgb4CI","st_dist_07":"KkFQOdlenvg7FsPGVgaUYKnp","st_dist_08":"XUgU1d9MSEMWGTICtK6YxdmL","st_dist_09":"FlnafjoD8v8hUkdJIeEZFi1o","st_dist_10":"CEd0z6hPzULPpUSSR1IZ6tpG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rVHEMSgfgbFoTdAEsFLAe5w6r81Dl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":891,"st_w_id":1,"st_quantity":34,"st_dist_01":"BOuCcyDrKthTyp0dzP08HZ4g","st_dist_02":"XFHcSbhTFW0GjijcFTGpOxOD","st_dist_03":"yqooHMSWpeb8Fk8zT3RDspM8","st_dist_04":"0uTecQ9Ajn9A0u8RBY06iXR7","st_dist_05":"ILLeawvo8OHgrXscqQ56wbBj","st_dist_06":"DFN7LiHnIpCnqQI3xjxNW0Y2","st_dist_07":"GgaAQMxtqpxOQxgEzjN9nBOm","st_dist_08":"Pz8VrvNYqpyIiuqlJcvggN8N","st_dist_09":"teHFUew2tdDR0IAmQNtuz4IG","st_dist_10":"BiqtdVlHKZXO4LB6d8iUnqb0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"P4icQ9m1QbMto8UEfSF97xSPwJIpdUgCNm1nuMNav"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":892,"st_w_id":1,"st_quantity":94,"st_dist_01":"hxcWVBhAuBgNr0mf6HaIGWle","st_dist_02":"O0GkEMa4Rvg7bRWtuN9YGxAF","st_dist_03":"z8j50qUZYi8zMyitf1kP5LxA","st_dist_04":"pVoUXcYPdvXwegsgGcm5ZDDs","st_dist_05":"bPFRcR7KwkaiVCiXU7OZViJC","st_dist_06":"ZzeInDNH9A08SC4mDysQOOnR","st_dist_07":"ZEogMwUqa7zzaop3SMpcuw1C","st_dist_08":"AwwREEnx2mVfomhlsL1hWRiM","st_dist_09":"6iWDI67dZcDThuvidab90moG","st_dist_10":"OQUzmSdZdBAWnnxYkL3nXoNR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SkvTRG1KBhr0vCE8lBbI6wvGQWerwgcWoAAQfaSxpxD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":893,"st_w_id":1,"st_quantity":12,"st_dist_01":"2X3mJ4wYvky48P4PLqB4TSBR","st_dist_02":"1q3E7brBcViE2N14OEYi0Ca8","st_dist_03":"YaXjPhablA5pkwsWeP8adki9","st_dist_04":"DcSPgS4pHV0a7brCFh8goQyZ","st_dist_05":"yLV6pzXqnwkL6snVDVYiu6NW","st_dist_06":"FAOnJy8vFxjac89HDxBS4EeE","st_dist_07":"UhUdlLhzB4mI5eVs0Uxb8Ote","st_dist_08":"YWZh96AgYXucxnvtALb2HsU6","st_dist_09":"m4t7KGJCANliYGmGWTcuW4l1","st_dist_10":"uLoya2UMxs7YFTlErWDeuJ39","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jMuDgjeTmDskoriginald5i4vm4Oio7M2dC4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":894,"st_w_id":1,"st_quantity":12,"st_dist_01":"O8nUcrxNTl274RpQeDfPoAJk","st_dist_02":"cOEkZb47EAvy74e6a6JEE42Q","st_dist_03":"WFL2tpBBpCgEd5NSkg5hmLAF","st_dist_04":"kpaw48zQ0fVnYct3IL8oP6dd","st_dist_05":"xd6CEYq2s4hgDuaX0tAFwTdh","st_dist_06":"lCWuDBCm7jV0natP87JUBtat","st_dist_07":"PZUirAvk33WLdnvWXkHGARZW","st_dist_08":"TdBq8HDGggBrVHdXug6TvNuD","st_dist_09":"FrISYaqB9vBZ4cQgDvcIcz2M","st_dist_10":"5DCm9DsEnhT0mr87uS6edyhb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mXvIEETGbnyd7SBus3JjAs9E4yGIPlnDLxWEmAHM2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":895,"st_w_id":1,"st_quantity":53,"st_dist_01":"QSueY2x3OCNPdmnqcbXWQN5A","st_dist_02":"RPGzwPWiFOMotBNMFOHwutQl","st_dist_03":"0RikcXzB7l8OF2S8fN4EjjJ3","st_dist_04":"TwRFS8onhyx6PXwB7XoexSyt","st_dist_05":"R8CfL09hT99xPkUKZIyeG8Bu","st_dist_06":"w37nd66yXbQVExwyyim2fsvf","st_dist_07":"ZgMHaG1Jl5fQtBo17qD0NDfL","st_dist_08":"FxAQ0vzOst0rSyR4WKJgXj4V","st_dist_09":"OaVYkZoaaoSn9bslIfEynoAi","st_dist_10":"lDkH6nBzsc8IiIsoC4xLBgBI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ubJpuYjHmdQwhaq4hZhBykPhR6Fcgus9fC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":896,"st_w_id":1,"st_quantity":17,"st_dist_01":"MKkXxKfR3ww42t2MleOwa2Kp","st_dist_02":"6ZtJYE1cplrtubHgli6qWfHP","st_dist_03":"o3hcndQF6qOHnBDKn7BAaEtp","st_dist_04":"rwXvXzPFiZtSLvxYaqEgXRdC","st_dist_05":"7yLqWAfvPm1QzR9zjqVh79rm","st_dist_06":"DeyYBDyIPmeD6xGuI07AP0VH","st_dist_07":"6reipPbBx7EFIMWKr0LluFTw","st_dist_08":"4uZr78VFyDvd8BYLmNhlwhYF","st_dist_09":"joJdt3HkIMP2vhNDbwWM01Es","st_dist_10":"lIayRiGDfVjCdlknwasNUGJD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ncN7gr3fdTQovnl0cgrJe5cN1foh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":897,"st_w_id":1,"st_quantity":20,"st_dist_01":"TgqAqTsaL93kzmmx8cHmNxAq","st_dist_02":"bkzKTqGNV4MB4PANPQwevhKG","st_dist_03":"wIalFPkfSVHR5s7zllKbclzG","st_dist_04":"L6PWvbufvj3rasIV2sDAZ5UA","st_dist_05":"bXGxVQo69irYK6m6b3oDLF2k","st_dist_06":"A7O5uOdgwZM2URU8KRec5R6g","st_dist_07":"5TIRUuIDYr1Od0pw6mKwKUz7","st_dist_08":"EomKTbuY2PjhadKfEETPFrAm","st_dist_09":"EqQP5HTBia04NkBT6JZwyQHw","st_dist_10":"FJaJPydkRckpIbGhEmUeyeZ2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Y3zcQihVqf814BXIe5Vy8D0MXnkSnpVx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":898,"st_w_id":1,"st_quantity":86,"st_dist_01":"9oLJYTnc7fcAmR1ayYVXWbOd","st_dist_02":"dqaOCQIu1vpHvWza4VdIAIYz","st_dist_03":"dc0ReldErz9NxAMqQySwcDmn","st_dist_04":"67jcPId35ClpjhYB0fKa25cb","st_dist_05":"uUkKndQOdVyYRnIe5iYdXT0d","st_dist_06":"TbHlZ9XwLv4CHeKn8vu4PEsW","st_dist_07":"n0QV3ZCE4hhprnXVFY35xTRF","st_dist_08":"22oQLgWTqNZ7pbqsLGgh8MHc","st_dist_09":"TPRmZOdUuLVZ8gOEZ2usROou","st_dist_10":"nNycwwRnNicaplb7DFHgQE6L","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JzhFRvfvuE0Yao6ZSFihHVcVfLA5X7DhAMXpM4A6MiCClTlhvD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":899,"st_w_id":1,"st_quantity":75,"st_dist_01":"1ABKy1ZSRXl0zn0k3c7otJXk","st_dist_02":"2jHoPTv0xaIN6H3SfFAZWNl4","st_dist_03":"8ga1SxGO0SjPK1Fk88I2GVh2","st_dist_04":"O2b0Pa8cegesj69mkY8qmRgv","st_dist_05":"BFDf31j6ND6YuWARBLEXoD8Q","st_dist_06":"qX24mN1CANudyqw8OHu32yUp","st_dist_07":"ci0h5LdssqmIez4ZCfFNjWhz","st_dist_08":"LsNdryNV3dBlXkyeDYkpKwtd","st_dist_09":"u58yx3jUCzHRqNfan5ZVd62Y","st_dist_10":"4ZW1wusykfN7fn2sDCsJ3EZ7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7x5KUhVpAjD1PiLlgADiEPYzlhVQimuEy59OplGMmM5J4M0j"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":900,"st_w_id":1,"st_quantity":16,"st_dist_01":"7YzftQh9OE7KB5WTFWWMPQxK","st_dist_02":"Iaa8V4xoDAF5beu4se8QlUDC","st_dist_03":"EAkaWxYBiu8yMlnjl58gqB0z","st_dist_04":"23oVxEPJ9r9j0JbZhyA98r6j","st_dist_05":"G1IdupihuNcGWPeMt9cmtncL","st_dist_06":"gQmNjTOjY5w1qBn2bxspvcXg","st_dist_07":"XDm96TyZtV6eKLZnRVJlS0nc","st_dist_08":"jOW4p9RFKazLYv98XquBOWcl","st_dist_09":"hMIl88vtH6oKy9FqMSydJJ8i","st_dist_10":"WHKEogqphYhSXWFWscZMW1Lw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ldCI0tFUsJUoVpNPl2cApVxgKOfFbHMxQeJiXZqUKLZCjA68U"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":901,"st_w_id":1,"st_quantity":94,"st_dist_01":"ZaFwaoVbTMGyTHgUZQ04xPIK","st_dist_02":"LxfLTdefpsYBjNmI9FoGN2ZB","st_dist_03":"ZVJgvoH2fpue389kugSDIrkG","st_dist_04":"8aCwatN6NSUiDzI0G3ejGNqL","st_dist_05":"5cEu5AuGWzkF8D7UAkDJyPcB","st_dist_06":"gKhs4rQg5DuenLYm5YDMIsVZ","st_dist_07":"ZYFCL4Eolu9fg84CE0kRUM73","st_dist_08":"gt3nAUKc7A893SZrbiz5Ux4u","st_dist_09":"ZRQSewAe7bxOIi8A9otqQ8bR","st_dist_10":"xIKD3CMXgsSgt3OA107QH61H","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"y4Ay0cmU0dx8tcdMa28WIa2bMnjpyoriginalmo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":902,"st_w_id":1,"st_quantity":72,"st_dist_01":"iVXPVRmy3QbhY7juCDrtrJFM","st_dist_02":"6OILk17y9zre4181DzRaa6iG","st_dist_03":"uUHnA2DPsYd4ahwstcehmNuI","st_dist_04":"KEHS7LZpFokdovqBTZ8TVkVR","st_dist_05":"VGXK5uafBvytNoRQDzlDiO6Z","st_dist_06":"lD42xaAoIWPxmmyH6DhTtJW2","st_dist_07":"a9xc94VwjYOiu168vwKuUtDn","st_dist_08":"VJneqrI5TWw7gblaAPEIYrME","st_dist_09":"Q8a4rh4Oy4mvA16asM9tWOXY","st_dist_10":"bKxQKwmkefwNZtHrcIMwSow9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Zicjn4dDOA8F3HejoC7v0uc8tJjQEcEtF7qME"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":903,"st_w_id":1,"st_quantity":47,"st_dist_01":"d0bU5qBg3md4eHZa617dkogs","st_dist_02":"MmhIiTIviu3O3GyWazI8dfgq","st_dist_03":"RMNvpd39jMQAB9lDY7kJburR","st_dist_04":"6t3FWd8bFd82GuB6KlEQhpHq","st_dist_05":"3HQ0Ngzqcky2mNR6WmZOJbz8","st_dist_06":"sq62sA3msxA2YjCzNf32Uoaj","st_dist_07":"qLDqvHjkrFlxHY6idx9INbVS","st_dist_08":"pombzblM483Rozbnw6rL7L0x","st_dist_09":"tPOLnVItMOoXVsSzvIdH4ooA","st_dist_10":"yeQKAPXWUy2dnnQ9QyUEYUTJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JqKY1jj0rOWxfpr0TwBKgTl3YBlpQoriginalv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":904,"st_w_id":1,"st_quantity":95,"st_dist_01":"ndNyjugIX73lezX8IpUkdrQ4","st_dist_02":"BiejnVNZWCxcB1DGbOP69csy","st_dist_03":"j5HzamwYVEJUdZRi82ayV09j","st_dist_04":"NYGZaLKkmuWOp5ukesCd6LoZ","st_dist_05":"bLyUbnXvznb7Nxum7cRUbVmS","st_dist_06":"IiUKevvPSDLA5vcG8eoKNeuW","st_dist_07":"TrGg2yEgSd6q130gKrUW5TBW","st_dist_08":"Igu8YP5ypK9x50WD0czuKzuG","st_dist_09":"igLnx2gYAW1WU2lVqf3mNEwW","st_dist_10":"mHLsu6rEkLZk5Fv8vECpMc5n","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Sbazgstlw4JgtYAbMEaM5uPH9uoHtf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":905,"st_w_id":1,"st_quantity":100,"st_dist_01":"GMkt5xWnla4nksdMWhCV2Dng","st_dist_02":"aeM2P3zrZXzSgXUY4BoYhCr9","st_dist_03":"F8qO26thH6UU84UiB76NPIyT","st_dist_04":"SCkMzIQh7GuPECJoyTZ4Y06V","st_dist_05":"pTIOqzRs6FSW2tCe3zkAB916","st_dist_06":"EOS0xbePDKi2QBqWkgjT7njL","st_dist_07":"iv7WQujWvqj0aJCGjKRj6cRt","st_dist_08":"8Xj8SrQm0LBo76lJONOKHIao","st_dist_09":"7yNAFYHXfZEy9lpN4RNRRri5","st_dist_10":"LKJnPoJMubpZoZJEdJIPrvtm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6uTOkmFz0Dg5HoMZyBJ0G6zed77pzroyo6fZ2jhHpg9Wkb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":906,"st_w_id":1,"st_quantity":30,"st_dist_01":"aGx5v3zVeFgLSWghLnLUC7uN","st_dist_02":"s5k34itZThxaLHs6UU2mE7Q8","st_dist_03":"3HJoLt605EHnThjyGZvLyG7b","st_dist_04":"CRgCW43EtJs1MJNejBARuARw","st_dist_05":"uGenazhW1dxcDQFPdcL6PZig","st_dist_06":"u3ncp8ql8j8mmHIKt4y1VTRx","st_dist_07":"BeGpM6gx1BJUw99fH24HljRg","st_dist_08":"J5T61rO3ILlzYg74SdeYSjF1","st_dist_09":"mGW7B6cAk9FZGK9zLo5LgxV0","st_dist_10":"kH5oNErYhrEAOxxbpcusNLcK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Xw340hYTYYg3YOcC3zfcr1WbNztoACrPOgWdZupy8ZgmNz6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":907,"st_w_id":1,"st_quantity":52,"st_dist_01":"rlw74WyVkODo6Bqx6LUsU90s","st_dist_02":"NDWSsOuo3wQ6J1Wijz0pr4W1","st_dist_03":"N2BilXAFAnUoWg1Q4ZbApUKh","st_dist_04":"TxxPucMJSqf4nD8kIIsn200B","st_dist_05":"d5CLXslsCAXv2fVZUGWhoLkv","st_dist_06":"lQv60i5iXQq6Zv016Vhs1D9p","st_dist_07":"E8RlNSMNvn58wTK1pUj1bYcL","st_dist_08":"VkEVWJjQF8LLp038grve1CZI","st_dist_09":"XAp1X16g6ki4gk6fNOy87bZk","st_dist_10":"69eyHNFZIe95et6rPWGIlW58","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RG1FENuhl3wvkjozgq0Ts1R4G4oo8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":908,"st_w_id":1,"st_quantity":29,"st_dist_01":"o7d3grQCFDOUBOL5NO26J0xy","st_dist_02":"PmuHdhw6aiIk17PxMFG5r98I","st_dist_03":"r47NG7PvRnvrOrU9U0iI1Etp","st_dist_04":"7MgurYE8ipd7wtZzaPQzOypk","st_dist_05":"tJDNkbCmFH30QX3QCLvBHKyG","st_dist_06":"nD96oIqk6FCgxwTrp6x54T3m","st_dist_07":"DuSjeuD4xyUzlsb1VqOczy1R","st_dist_08":"lBWpDptKHreMw1rSW0opTiuS","st_dist_09":"L51nmu0MwFEK5Pj7YUmZL9a3","st_dist_10":"tBY8RPVSkY2IcrRsDRuu7qC6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VoPU4sinstpR4n6k0jc1yGywHGE0Sz7mbJaYh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":909,"st_w_id":1,"st_quantity":51,"st_dist_01":"dds8pyN5EDr1fNg1vhIJw0X7","st_dist_02":"E6pBwiJygRAmGv9zTDGjde1a","st_dist_03":"axk5gOSKBS1SD2suRYCuNM32","st_dist_04":"zTrAx8MPzQwRgXWLeUE8ng7a","st_dist_05":"5XMomwt6lFlwU8d31HXbXXjf","st_dist_06":"7cGiU099py8YhP5vTOU8a1XF","st_dist_07":"oDmm6QM8cKGG35Z1zY6wH2gz","st_dist_08":"mZalb9yc0dNuCZu8vGjBjJgn","st_dist_09":"MnIo2RcATkjrarSy2KLTEQk0","st_dist_10":"pPbUUZ8xD82PHuaK0Ft6Ahu1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZF6Iz7TyRmeFIS66IrQB6UVaODnGb0KMP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":910,"st_w_id":1,"st_quantity":41,"st_dist_01":"W6gd5HhbR0jsLAYQmGNJaIyY","st_dist_02":"bKmC4dXT0MkXePOofRy9es7K","st_dist_03":"zouNWpgA4zVbFLLgKKEQSKyE","st_dist_04":"ZAFqsV4YG7NfetsNh8zsY7iO","st_dist_05":"oiBRzjV9g4q9Hwd1tLxgj9CD","st_dist_06":"VjGLPEZNvhBIgfK7wA012DqS","st_dist_07":"bL1FIWAoIoiy7kR4SeU9NC61","st_dist_08":"nq4YMyNg6hzads8e4WCPKyzF","st_dist_09":"h5rAuHlzTEvN5sGRav6LUQOB","st_dist_10":"do379930TtBgiRqC9ZSjo2qo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"veo6miymyMG4nETkC8tb2SaOr1aQQDDqx56GxqBa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":911,"st_w_id":1,"st_quantity":39,"st_dist_01":"tLwurqnlzaxyjIdCFMWS7ofT","st_dist_02":"a4J6mNYbo2x1hm81VLkBoAAO","st_dist_03":"kgagCPr69CnnXYFg9RWcefOs","st_dist_04":"2uDa7j3W8eRRzGGv9HMKcNwG","st_dist_05":"3vQYRLaYBSg3P9zOskNRGsRD","st_dist_06":"EX51bC9A5vSEM3lzLszjwtQ1","st_dist_07":"5dA1dnonHosVKRThdTXeNOOL","st_dist_08":"80XKVGWgctETVEohy1y4EBRm","st_dist_09":"WxN37ngTOl0pzgOdH5BbLwCi","st_dist_10":"XmqGxmS6r4L5lQl0E0MymjvN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QMpBdrbMRZVCrmlXjJduPoRntyd4bj1JvWWy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":912,"st_w_id":1,"st_quantity":56,"st_dist_01":"2Bp5hfxkIrpamFLu3GUMwsuC","st_dist_02":"fSgfSy862CDua7O44g5peDGA","st_dist_03":"EXMBDgFTMuylLnzy634zYPAc","st_dist_04":"yrjsG3fGyrdTniAdTa4zub60","st_dist_05":"lN1bYnhKwSphIf3aLRV0egs7","st_dist_06":"5VtyyXOcDhE7GlxXqWPLYLaC","st_dist_07":"G3Pe2Tmtol2UQ3cPrGHBMFW2","st_dist_08":"fkf0NJjtyqeUvGYzWFk8Rmps","st_dist_09":"jfV1soWMW21OjzIw2wABREow","st_dist_10":"WKnOOlERIBUi6kqkF1UIIBwD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iJoe3FfqtSkygEWm25zHwwCMQgvB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":913,"st_w_id":1,"st_quantity":34,"st_dist_01":"w2IfFudilzwHRNT5PyAz2GEO","st_dist_02":"khh6TOZJjZ7pZAJduxqcutme","st_dist_03":"Fd3f2JT7GssrbZpT7Uftg5h9","st_dist_04":"TI3dtSd8Gpz8wo9WsOgKGi97","st_dist_05":"YR2XGKkaU4Aj9zmDgB1Liv1w","st_dist_06":"WUanIxLoajesa0GXiJwRNN38","st_dist_07":"WOyN4rRN9VsUEKgBD1YUHbWJ","st_dist_08":"mtywe8F1wQSMIwchJe0vzt0s","st_dist_09":"tpOlrvFDRqmog7ynL8vqgnqb","st_dist_10":"Y7Ht2QTZuVYI1sOnvwrEltCa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"moCHNkIyVbizgkh8OogGYNpyOn8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":914,"st_w_id":1,"st_quantity":45,"st_dist_01":"e0WMCywCw08oel30XtZQFsUZ","st_dist_02":"8Xu0SQjVUksq0wYOQ7yxaLhl","st_dist_03":"KsoF2hSW4uWrctPr2CLnTxOq","st_dist_04":"2HKMQU2XGUrMUh8ivpjGxq5Y","st_dist_05":"oF25d0AqkOljbu4Opi0AWVyb","st_dist_06":"FJrZEhwwwld1k9EGOwh6Fxr4","st_dist_07":"fCmSmnY7poQ0OFHfoj5JjTQc","st_dist_08":"b4fDGRmEQaP7U4WhZTPWegcv","st_dist_09":"nqoHRf2snHXyYYWK5Kf87qp1","st_dist_10":"r4cA1lRf2K4xPEFDcbdtqdUU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iTX4ZViJBOG2uGKZW2sTZbgxIHDcV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":915,"st_w_id":1,"st_quantity":56,"st_dist_01":"q9A5Nbo59OMEZ5VDFh7VpOmI","st_dist_02":"TvdLIiRJTDXeRddXD3dXFuy8","st_dist_03":"EluLLZvSGhYuxx1Xh6EEM8eN","st_dist_04":"dI3qaDojmzbnmFKp2ulklG3Z","st_dist_05":"WQZ4UOCR0NiUvPwzMxND1BwH","st_dist_06":"rBgs2WPuKRjHbpeMXYkCXPUo","st_dist_07":"4711XKFyyfGAIdZ3i7u5mYxN","st_dist_08":"FIdxjkd78UnDlobdIAmwcvHs","st_dist_09":"XG1qIypljri5zxWeHbLISz1V","st_dist_10":"pqk636kxMVGyDAduck3UnOKy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O5h74c2HzOFPumMNsEKSatFPVlapu7q1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":916,"st_w_id":1,"st_quantity":66,"st_dist_01":"j2NIVp7l1EG5vQ7lGQamCFki","st_dist_02":"3VlLO0vIb6UCmkycZ4urk7iC","st_dist_03":"S19z7akUnjAVzj44OWNQDre4","st_dist_04":"KTminHQXAiMb2ug6DaR5gFS2","st_dist_05":"6yolYY9FGrDJWKsCmsGk5Tt0","st_dist_06":"ttBEFhrSbKKHG5SgEcXrMaDr","st_dist_07":"tNJf3tyYKhWLWLoDcHrPUlBq","st_dist_08":"MkMJahTpoxiRxszYvXJi0cjf","st_dist_09":"ipwOXp6JPMdRUk6fLcNEdNB7","st_dist_10":"1OU2J5Fkr320OU3L231CvhbM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MlUUYvtX5RwmJNArBbYFjBaWXU4UGuU5cdMWBQQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":917,"st_w_id":1,"st_quantity":85,"st_dist_01":"X6N2tvRP2LdOiOCQjdBvzrXH","st_dist_02":"23dERLABIHRvoOJrte6ex2fY","st_dist_03":"v6zD5IAJzMQXbQzjEUthADWc","st_dist_04":"V4vTB77M29N7w9InleswAsoJ","st_dist_05":"FDLm3UkKeM9CnGPHK0l1eGv0","st_dist_06":"gNl7CZ4bahcEobLqYCCNpp7F","st_dist_07":"ciuWzjru7eK67RZcv736IRMy","st_dist_08":"92fozzcxj9GtPTgtIqfcNNnL","st_dist_09":"JhQ2m6D9D8ERJ4OiCkpDrZx5","st_dist_10":"8OIJWfAL2O5wZjoiGo51NYcR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"obvzBegBpOpSUI7EH5JY88aA4th4e3YKyeHN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":918,"st_w_id":1,"st_quantity":47,"st_dist_01":"zphWAwsn3EA00eTWgy7wL1ur","st_dist_02":"CfcSwKUXAdMlJvVGCxqik3RO","st_dist_03":"RyirxQXfwJKi0chGpjgxdOR5","st_dist_04":"IILmg5WZ8UDeSti2sW69gnnw","st_dist_05":"zSrJiP4lTcMoHqSkloOGNgZy","st_dist_06":"VoHtGqiCN4E5BnoxXljkwThg","st_dist_07":"dtv3oEJzPVGgzOx00b2p07qt","st_dist_08":"FQlJj4MouN12pdSaWmstxx24","st_dist_09":"QzlNza74Gqoh8UCIrIWGKXVu","st_dist_10":"qGp7h9Y0InZnGFcdvCfWHZhb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DLFmHksRF56FY5dDfxPFCRyF6SathpGJR0RF4wQoI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":919,"st_w_id":1,"st_quantity":80,"st_dist_01":"rafgp0hIqQhrNV2SNN3TtirP","st_dist_02":"kU5ra7dKmmwMIdllbADlYCDD","st_dist_03":"JNSDUDfXQYvW6NCYBxSWrC3l","st_dist_04":"OCqegXPTolVwgbDaVgefz71w","st_dist_05":"mvXrngl8OeCVgnakBsDm6amW","st_dist_06":"lO5MFzqZoZRwjcBNYwHtn1jm","st_dist_07":"C0XkbhAxtjEsctFsZDav46ya","st_dist_08":"8WxraKITDBQg33dsQU6BTR0Q","st_dist_09":"OHTMZYIk2YRSZcb3qGXgglLM","st_dist_10":"BjiWGjN6yhe2nPixhE9eeFvW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ARUgduHR4sLwzcxGYg7RrGopR6JwrSzLZyhZ3OH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":920,"st_w_id":1,"st_quantity":73,"st_dist_01":"dIxJ02xNJCd2Lhw6QZQrAXkv","st_dist_02":"LMeAioVG44XZRKG9d4qyDa9O","st_dist_03":"oSAEmM1dEEaxjh9jmI1lu4CY","st_dist_04":"ySBoyYQWw6z25xRpVCoA61Ds","st_dist_05":"MwhzoHAT6FcO846r45a48ifS","st_dist_06":"pahYEas4RZUohfCHMqgEutXt","st_dist_07":"268QBcIrgmp8vNHrkPJAzCKo","st_dist_08":"zpjveIetyfwzAjN8XBSO4bVz","st_dist_09":"gyMnyY0Eg96a8bJBNIcNRoMf","st_dist_10":"IOU5ZsX1EeXXSthJvq0Hepgs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VnpvVEe1Hqg4V9nO43ARDsbIFVU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":921,"st_w_id":1,"st_quantity":21,"st_dist_01":"TtRpGpcxngCoyOgjKXJ0Bk41","st_dist_02":"qMVERAhDxQ7tGDXGJujI8Nso","st_dist_03":"XWxlymGNjIIzne5uvOX4AOka","st_dist_04":"II9DV5ScUfNg0Udqy6ZJxdyB","st_dist_05":"L0yKZdrWljvJfEq0QvlPyF5v","st_dist_06":"i1sWTPWkiOLptxrCG57S3fWb","st_dist_07":"f6hjf4VwTOYc6KnnyOaWR2RD","st_dist_08":"05ZZCdj8K7LxPTo8paXZgWO0","st_dist_09":"IebHs8yTDXyGvGKdTChKJsTA","st_dist_10":"hViAc7P3FsssqNuqzNaTEeZm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9VzIjsbjoB0dv7CN6uXQSJO1W6DSwN1BQEGpLhwLR7ARVH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":922,"st_w_id":1,"st_quantity":95,"st_dist_01":"0roF5CBL6m6SLkFY91yASeWO","st_dist_02":"OstWj8ukvVEUfdDHTPek98PI","st_dist_03":"Xc9eR4P25L4wbMhOEFdcmwG2","st_dist_04":"g32Xus2Gd3JR58AMNnmswSSc","st_dist_05":"nd9Z1WLIDwWHUTI9nnXoo9Cn","st_dist_06":"9oaQtJxvZ7FaAsDRYuETg0oI","st_dist_07":"2l41n3IsvEB8AVOdslOPYfBn","st_dist_08":"9Ib22jxxdkUSFeJaIi6TSBwx","st_dist_09":"Nj3WXURpKRekEJ4PzEZdY6v3","st_dist_10":"Ru2K1BXz3kmKfr2ksVy6QbkM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Xm5LcFvL3NX5dDUpHmcnFMoriginalk7cowVF2I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":923,"st_w_id":1,"st_quantity":19,"st_dist_01":"ytUaGlqRqesaaCq54BhqHqDq","st_dist_02":"6de7SWnx39Ur1PDg3TAED0XD","st_dist_03":"8OmztVnJ8tH7NGYLiHaaUzva","st_dist_04":"WUZvAxWulAQ86gHHGiYV3Zdj","st_dist_05":"hpmE0G7KlMVwMyTxJ3eBzqKv","st_dist_06":"LFM9zxyak50fQPSkrl2Wy1m0","st_dist_07":"8EhNJmRBWA6EV0YZI3RTXSCs","st_dist_08":"poLOVw78qS91exwDweR8H2KV","st_dist_09":"6n7cltM4Er0zwAXnZSe9qvKb","st_dist_10":"yfvgXR8oOt2dxLK0ym0dkfjS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ElYpb0tcwhJIDJAzCwlMF3x4wqSKYfW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":924,"st_w_id":1,"st_quantity":94,"st_dist_01":"fmir6moJqTTZgF2i3KnQIRk9","st_dist_02":"fOssBCaK6Cwlv4VsMpajmcgQ","st_dist_03":"cg1ZiEJsKtp13wR8nBitlVd0","st_dist_04":"ytI7kyCCDPPHFfeZGkyP4zVe","st_dist_05":"HR6fK7SGW0Or29BhdNEGq8Gu","st_dist_06":"5oCOLJyky4v9nzr1PodW6gLM","st_dist_07":"iMw7JbVL9ZuCsa1ZCkKzdHnE","st_dist_08":"z23f1BapFIKOsIjRgq1P7eXg","st_dist_09":"QyX4BkrFBZnvNua6tnbUvoE2","st_dist_10":"N0wabi1AuJkWqs4zba3JNiOq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Xhx1XaJgeaQZ1VtGzd9OcVFa23nHQK6OKI5Ya3Bp6Qy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":925,"st_w_id":1,"st_quantity":46,"st_dist_01":"H8olMdgRbMT3CV0O71WKgltL","st_dist_02":"boNwH9aQePW7oc2MVqaXho4q","st_dist_03":"1HzPjniZz1HTmIksrQ3gxM0V","st_dist_04":"4E92Sv7XaaQ50l8DRSFbYDvc","st_dist_05":"qEJNOyDxfp4U1R2WBaoyUMjd","st_dist_06":"8fwlRQqlXETU2IKO1s4Sbmpa","st_dist_07":"C0DtU43obXHJ0VKPKcNVBF7b","st_dist_08":"pNv94zdOTlFXGVW6vv9Lgz5e","st_dist_09":"T08guGFRsh0Ay5UwfDOlBYiI","st_dist_10":"Bq0fvCxb8Eey1q9RMhlVBtQd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tJJsdRtM24S0GHp0K7m3kC9XszxJC7JP67bHHgl2bE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":926,"st_w_id":1,"st_quantity":44,"st_dist_01":"P7xVRcd6YHpFyFM87Xno1LAc","st_dist_02":"oYD0FyWk0BRqHRLZmw117wZA","st_dist_03":"rQVLNzTCox3VU5S8vdpWg39O","st_dist_04":"ayaEi5m7T14mNo1U0mXP8501","st_dist_05":"90CplCqu97lTKHv8hju4vW9I","st_dist_06":"rVT1EPapFp73UkBw4zN8Zc0B","st_dist_07":"H5J1dJvOupjIX17sjP8vBnjL","st_dist_08":"8bTc4N8M7YSZPn7u4u0GhbbM","st_dist_09":"9udfB0NPlyvqsFixWT8smte8","st_dist_10":"9rN8l0XYRBzzxicogFvmrOhg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4gkgbKKnIIoG07K14YVpNINHa1Ef5CLwK3dbEYmzXCLfkuuVP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":927,"st_w_id":1,"st_quantity":29,"st_dist_01":"abMel7Zi2cZt43uQNvK8fNCc","st_dist_02":"O7N7uD93slA2s5zlEvRoZlW0","st_dist_03":"VVfkRxR0C5PEEBbiwMf6yXo9","st_dist_04":"ISIod4HuSq34AvllvWmNsK6C","st_dist_05":"LeA7l54NpeZIwyhkx5aNfchj","st_dist_06":"TCpC6PnqdH7thsXVB61C9Dum","st_dist_07":"MKJG1VxJP2aFPld9pYqZC3rF","st_dist_08":"2AgvbwlBEtonHucpEg5aBcKz","st_dist_09":"WSZDHZz5wuHqVPOy2dyiYPAU","st_dist_10":"rzf7JXeYLz9VQfN9taIkP6V3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OXd9t37zse0CdFgly3rDpb5BkikGmfcvRi3Z5BLqnJz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":928,"st_w_id":1,"st_quantity":79,"st_dist_01":"kBigUXX78ryZASgc6KYHzPAK","st_dist_02":"1lpmsflOdUwNJJZ9g4xY8ETP","st_dist_03":"0HzoWIiPPU62U0fgo3YBBwmk","st_dist_04":"jhrF8DOkqFckuEJI4fhvvVRW","st_dist_05":"aeVVVu2GfWnkNmfs9gIq4pIU","st_dist_06":"gb3oAgZsRyjxHFdtTU9CkEqb","st_dist_07":"xBDiTRAxCUdlyZGju8UVJGJR","st_dist_08":"8fCEJjgbT9iraczoEe7QwEYK","st_dist_09":"9uskRFrPbwH1Dim18KBL8Xct","st_dist_10":"PMMnTivi1gqE26Sv3N0sIGMY","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GWCZ05BicrQJsC9o9XhQgYodXhKMoilfUi6iqRLZTiPzdyzJ9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":929,"st_w_id":1,"st_quantity":26,"st_dist_01":"sGEFAYUHzlJ7x9CFMVUkmZRr","st_dist_02":"Uog50fqp3dTAcC6mqWNgVF47","st_dist_03":"d4fbhFz6vg0E5vHNpUrLLfJ4","st_dist_04":"mp4HOBXcKo1SnrwWJqtetZWE","st_dist_05":"gPWFM0BDRCO4A5uyjHu6m5XA","st_dist_06":"JsTem8EIsIdYhmFKU0xnkzgB","st_dist_07":"OVW92TypDIm36ZjFg1yNaIGQ","st_dist_08":"RMatUr1DJCjqqVa5p9svAx5c","st_dist_09":"ITd6ujy2SdcSaDqSPHU6x3U5","st_dist_10":"G36v7aXmcrvDHwuvqQb4ituG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PEvpeVxFkzhMm8nPKgoK4gItG29jqO0N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":930,"st_w_id":1,"st_quantity":51,"st_dist_01":"Kf4K5rVq7P5Pe87YWWDydCmg","st_dist_02":"guVy4IYJEbNKd2n1om2nfPOF","st_dist_03":"LC9RMQmXYyK4hHalYN4XdmO5","st_dist_04":"qROeEuCp2ol8PWFaJ0qg6mtZ","st_dist_05":"u80u0mZJJQ5waYaYaqs2pnI2","st_dist_06":"hMSMQbV8tAuJj2nLXSQ6pDxp","st_dist_07":"Dc4rWIcgESzbLFOWyLgaWxy0","st_dist_08":"X1fijxHq5qacXaNNkP2pIGQu","st_dist_09":"mv9wytTz5PTRKa0IjGkDMi56","st_dist_10":"rUIaFr4WWCGPKq8ox7tN4xjU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lsYjxBwKvJUr9dXiZIXTe6sCvb1iQh5tCn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":931,"st_w_id":1,"st_quantity":36,"st_dist_01":"h5eepTJP5tItFlE5n9HuDAyG","st_dist_02":"a1ZiHz8KyRolwpjyItsdf0XR","st_dist_03":"MY6GVCscHjRNCGW2buAXcE8w","st_dist_04":"mjtSfXydhZIRZ9XTjEmpKVjN","st_dist_05":"O4R0nAv9AZBHRdkOafQ2BRIX","st_dist_06":"rhTwjparGANVxDppoGNQpyDu","st_dist_07":"1To55LmwCPzqYG26XJeeAeu4","st_dist_08":"RbBegMFcHKdniuzduhjLc0Lv","st_dist_09":"UB7cO4xe6yTS8U4sFzqlT73V","st_dist_10":"dha3H8kZASa8QbL249SetHvX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"unz1dzNVwgFyu1BEbbry6E7t6K7MH3foJmMfB5yx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":932,"st_w_id":1,"st_quantity":32,"st_dist_01":"bXSN5Vh39hQCuIZY2YYiNSiY","st_dist_02":"N9tY5AcVlFLTrnUyJIMTZmnX","st_dist_03":"ddRRCYNRVpFh9BKsxuQezrjB","st_dist_04":"cJrUZzgWLRsKsymxhbsI5I1g","st_dist_05":"y28MtjDxPpNixGSobZgQ9Um8","st_dist_06":"68aJtkBpUV9uGAO9jFVZYV4F","st_dist_07":"IwszTBGkultfpreE0LA473DA","st_dist_08":"A7O7UKlhupOMfQ4MqotRAr1M","st_dist_09":"tQyMK3MWpSL98krkLHtkSA6a","st_dist_10":"bImzRlLrkkcr9DxtB7PAx4vn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZUJUOCTxzIegnmZsnUUylPfbrjUNM45h8IM6XSw3t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":933,"st_w_id":1,"st_quantity":55,"st_dist_01":"cZqKCSx0uarrmImsiA6vcbIh","st_dist_02":"yx9tDYqe3FZ4dOcCEtZGyO8j","st_dist_03":"DKq6b0CQQwVNvj8LukA8wzeU","st_dist_04":"9hskcz7NamSUOmj9IrXzxanN","st_dist_05":"yfEuG0BVOqzK0Xs8lxWkeroe","st_dist_06":"cmrhg69BfswvNZhB31F00mQY","st_dist_07":"MJBrFdovqapLoufzuSaXA32B","st_dist_08":"7f4oxbqyrcsCMlKipiI9T0yz","st_dist_09":"Yy2gqcZxOmvsRgmclTjm1J4u","st_dist_10":"tiF2Yus9ImsP8qYSfv9tYyeQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LIlyyQmfDJQt9lbxBYNyM6wEOJTLp3gruLaLuD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":934,"st_w_id":1,"st_quantity":30,"st_dist_01":"uLQCPqWVhE4gO7szKU74Xkpw","st_dist_02":"3fCcilv3jkMMxZJpaMAiWVKF","st_dist_03":"VaVXQuXXDq7YFX7gtpZFVJe8","st_dist_04":"2G6WmPAxldQIi2i5fmFqiU6U","st_dist_05":"qyBe8VtIvUOOgGAdYC8KbmPj","st_dist_06":"idZ53tsJe2syYtKeRDB28Rw5","st_dist_07":"EK8n2RX5UmvpNa0wpTu5o5Os","st_dist_08":"q5ZaqCem6JGfeRkejNPHd53C","st_dist_09":"fhUysiuXo3bvUR0GtIoml7jT","st_dist_10":"HuyMuhENYU2LsulMb9U2zomW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4Bt7dghjXAUhJ01ahfjdmqr9mGyj3PrnHGq7IN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":935,"st_w_id":1,"st_quantity":46,"st_dist_01":"1Fkz9gP5UivR8wkz7t8KYz1R","st_dist_02":"FyUF2zdsKxaAGSKGv5PpiFgu","st_dist_03":"uikktxfLkdtiv7MJfFb7d7Ef","st_dist_04":"hM49aIZbkzC27xz1DF2iXHa8","st_dist_05":"Kpr4g0wpxu2l4kOJhjarMYrc","st_dist_06":"F0njEs2E0oMRnUxY5ZVENqsV","st_dist_07":"77AzijW0Pu0tsIceRpVd2irX","st_dist_08":"l6wMcjN2LWR1wZP79W2Jn1dA","st_dist_09":"plRmTGSMAfBARhmojFn1EvZ4","st_dist_10":"604x6s0uZYOmVpz4FgdOoqkX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FuSvz6originalv2SDHj67g3r7pUpMb3mwp4Eg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":936,"st_w_id":1,"st_quantity":54,"st_dist_01":"cS0Pr7unHgNJPGGUldx0mSPk","st_dist_02":"EvOxn8VZ2VrDJGYozRyCLijY","st_dist_03":"dmWko0ygiSdMYmiiw0Q7DQkQ","st_dist_04":"fYIygBm26jldFTX7BLDKXv61","st_dist_05":"gRmd99KR7ndIrr74qkQodfM2","st_dist_06":"pgyjcnQotQLGl60UTOGRaz69","st_dist_07":"bqInnOat5hYwyHn82431O6a9","st_dist_08":"vvnsxg38a6HAugiJFHMEgEvp","st_dist_09":"OArnzGGumhBCRM8lqDC6bnVQ","st_dist_10":"nl6YqEppKU21mNvV6n3gVaZt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MwjbZEw5t45M0rkJME7apLD0QAKM7R20CSzwc2k3r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":937,"st_w_id":1,"st_quantity":68,"st_dist_01":"fQwdercDp1u5wxnQfjL4XjOf","st_dist_02":"Q8GaIw0vliHV040ARyCciRbL","st_dist_03":"XRWAWLKpeFEZ5mRNhQbWaE8D","st_dist_04":"6EeDsU3CfFFqAz7AqPmN7dyr","st_dist_05":"tZ7MqOQJn9oYlODclSirYNJ2","st_dist_06":"JrZiOunRer9LrrQse7BpZSFZ","st_dist_07":"wecs35ZNZJCshl1RWSNNu4LW","st_dist_08":"qeiWwYX9d2iatEcWWIRLCntF","st_dist_09":"2sRHHHMis0eguvvfqGcikTX2","st_dist_10":"CZiK2eOcq5LvGkylzmxO1jtn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ris4lP1X3KyKZhFKhugVB1dnLd4biFABU5KEoFMlbAyi2PSf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":938,"st_w_id":1,"st_quantity":89,"st_dist_01":"ZcuIgtFiPzlxSzv9Nc1ZVIiP","st_dist_02":"cpOLmHH2r2BJpcHMZ27vu3OJ","st_dist_03":"usO05dleau12ocKFqDP0OWTR","st_dist_04":"NjEUOQ0viryRSum2TTH5HfgR","st_dist_05":"9FVlVBlorUrbecFAjUDNr7LM","st_dist_06":"FHia5khR9l9i3lr9hFHpZODc","st_dist_07":"nQbPe6CenJlfHzvpkSYV4c19","st_dist_08":"Yzm34v1TWxKi1MhF7otXyRDr","st_dist_09":"D6CzZPW3kTrbgbcNQW9jakuy","st_dist_10":"CaKWxZmEnasVP5a3z3bEXuIs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aEuGyb0RPOg7dNW4psy4ILju6YJnSwxJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":939,"st_w_id":1,"st_quantity":46,"st_dist_01":"pX3uqyUaqgOmfQWeSnEmRR5n","st_dist_02":"B4IMWbwRc6qZwiXCrWK4gifN","st_dist_03":"duDifmamRow2Xfjp1EaIl4qs","st_dist_04":"ZTs5lVydrVFYN3dlfvPV0Dm7","st_dist_05":"Rhf8bpcdyNV96xpvxClKbqeq","st_dist_06":"px0ypNc1yikFeC7BVlohZPWL","st_dist_07":"S2U4FJ1YGiqbfveVxEppAWZ9","st_dist_08":"QMgaBWZmKW9waxTZimBbI5r0","st_dist_09":"0kXrNbhrHbzVkEwAZHtq5D5q","st_dist_10":"WC7uSMwt4KY22I49IaxyER85","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0fUNqfDxXH1Pv44uLaDHv9LTpzwPFx8FcgxXsCl5D3DcoIIpr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":940,"st_w_id":1,"st_quantity":31,"st_dist_01":"2Kmjz0jeZ79Iq5whRoXrP0Z3","st_dist_02":"o2reMuuaOw49oXnuFVD6CW96","st_dist_03":"TAiZyGsecpt4bERuHgzip88x","st_dist_04":"AXTpuzTrCsmypxIUS3yCzU89","st_dist_05":"2Eg4B6E5sa7xLDBMvfsbS9RQ","st_dist_06":"zYzjfFjyO6hJLikkwhdooENS","st_dist_07":"eDdKHEip8UFt4RxPi48HoKex","st_dist_08":"bFh90Zth28tY7Y70iTCnIczh","st_dist_09":"y7HGQ6Py0lLx213UcmqJsKJp","st_dist_10":"4q5Ywp13K6LH9eVdl5c1td6B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PmbgKw1Udyq76X3fvLe0ERACu6VyZ0SP0NtBxVeezLD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":941,"st_w_id":1,"st_quantity":16,"st_dist_01":"vi8zvLvVPUX8rMzESMjZrnQk","st_dist_02":"D81S8IBAw2lM56BWnyRcIrkN","st_dist_03":"eg7N17KCNjEC0kAA4LzxpWwy","st_dist_04":"GtRg3Gze0fn1EBIbkykLoPNy","st_dist_05":"j7QErxIQZqd2YtpvxnIDu3cp","st_dist_06":"oLFfnJGSekb8DLrBYYTlt8if","st_dist_07":"l3xoprkCcDhRCLL9P3ju3xnz","st_dist_08":"jv4nkJhNyZMtiAlxv9FUoPM8","st_dist_09":"3GWmFRGp2Va5JCyeo3Ivm4H2","st_dist_10":"M7OpBBu8HPWpuiRRRPwebGYt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"I3DVjkvlzSmgEwMsSEUiKGa8otX9xMUcwWlI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":942,"st_w_id":1,"st_quantity":93,"st_dist_01":"dXbFPI7WLHXVdH5dSaKYPOlx","st_dist_02":"jgC0LjtxYIDXEJxibqFeb6c1","st_dist_03":"MNSTLIzwrfJX1bUXR1grA2de","st_dist_04":"02RfA0K7HtnMTpODANz22FRn","st_dist_05":"ANmxtBTVyBrScsqodl3M8fPF","st_dist_06":"w0jmwzgsshn4zObqPgkAwCta","st_dist_07":"nE4nT0ZUPxBlkZn1kCtBFP0V","st_dist_08":"5cw81NxYC9a5zlBNMcdgcSrR","st_dist_09":"hhnYL2wN2NstzEzKJUzJy4TP","st_dist_10":"TLpNbJZKnLrwmVc83SbzbgvS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"U5ioRCTExvfU3ZEfP9RWkOBM0CDs7JlthIRxgfVAKNMnIG4l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":943,"st_w_id":1,"st_quantity":31,"st_dist_01":"py3cCtfZ4akFGDvO2N8a9BSd","st_dist_02":"v5EC6fB2EPri4sbT2JXH1c4K","st_dist_03":"0a1rCwOinnelrx8ndvlWj1qP","st_dist_04":"CLBacrS8s0dn9cKouuUdvHNV","st_dist_05":"u6gQKPWngEs0A5M4r6QEO3u5","st_dist_06":"aUiBixi3gwcAdo32XextHXrR","st_dist_07":"9sJ466DhmCYDVFLjSmCFJAqY","st_dist_08":"ut91Dd4S5CG7m8Bf4TeHJTNF","st_dist_09":"FJfvb9AkdhmQjBLvw1TB41rz","st_dist_10":"3PWB124kUWWbwlZibX4k1l3N","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MLXxPcgQXp9q3F6Wj2S5S2PHsYmQsEycZMd3crnKpZGOrVkh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":944,"st_w_id":1,"st_quantity":38,"st_dist_01":"xzLqYUgbCqhDpqdJbwHs013D","st_dist_02":"DF735yHJzqm0VSJajN7Hktui","st_dist_03":"6xvC4eb9H9PBXXFiXUISYd9e","st_dist_04":"V5OkSnbesWONZu50CmRUxqbC","st_dist_05":"OCiFFuXYf0iJTCiENuJh4WEY","st_dist_06":"Fbg6IAQYwoEv0JfvBRUls4ek","st_dist_07":"z4CTaOBxBMx42f4YltWMzWKX","st_dist_08":"woTi6joqT3GwtMcgqoWvpFXC","st_dist_09":"oeIvVJJyJV6pbZlF57tcQ3z3","st_dist_10":"a1cVX908s5SGZBC3RIoqYlbs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tY91to5tRf1nSpGZA4XfwHwGWimkxobw37l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":945,"st_w_id":1,"st_quantity":75,"st_dist_01":"jz9eMkKZtl7sVAoq0JWD3JG5","st_dist_02":"85NMDRjhFeUHdaDI2rQ3YC18","st_dist_03":"CBetmaZyQir5lUvE2wX3y2ua","st_dist_04":"ewz6prDPhYnwGG4KoYgkGHuh","st_dist_05":"GMyVDbyAgwGxNGUVasoaLixL","st_dist_06":"7CsTaJwNnA9cXDtlUn9T0aqO","st_dist_07":"Z9OGKFh52vU8Ok2Vuj8FUl7P","st_dist_08":"Qos28jHr57sK50BAF6LFRAFS","st_dist_09":"fT9SWuMU9qvlc1bFrIzX0TB4","st_dist_10":"Yw5Gd2A3XbXQ9Y4YW4oBHaGM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mWoriginalOG4qDNrhvORGvqTC69qTa0KaANWiT29QXxkV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":946,"st_w_id":1,"st_quantity":54,"st_dist_01":"J892HFfyAOwlFL32RDYcdU8q","st_dist_02":"KtN0grVYdBLE59e4ZDigHT7i","st_dist_03":"BmGOcu1lG6gU6d3p03ndX4zQ","st_dist_04":"ikwo28jbwbvVzzSXHac6tebh","st_dist_05":"KUkbOh8TBXN0tBBQ1wKtT15u","st_dist_06":"hRduD7yGBrcLa7NOSwo7fk5E","st_dist_07":"COnozQ6d7L8Ut5Sm6Rf8Dwsa","st_dist_08":"IlFDCNBZLQBlprvI4xJE9iUo","st_dist_09":"GW4FFUfmJvEiJF3W4Ge8NIKM","st_dist_10":"1Zygbw7layxK2WouAHhLiLrE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2FD4r5JjonxOqWmGXkgWHq6KDvmOax3VVKl1ljROIkNjnpW5m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":947,"st_w_id":1,"st_quantity":31,"st_dist_01":"YP8dywbJn7tDSaXMr8WtLu22","st_dist_02":"DTDupaDTNgj7vKfnHbRDf7gQ","st_dist_03":"itFLqBAzxk5YtYYffTyOuJay","st_dist_04":"wsUmLANJEFWm9hf1DJR9I08a","st_dist_05":"kUSQbtODHEw4zDPcV2QROOVZ","st_dist_06":"xkZ6SBnb8fj2zakMfuUzewoZ","st_dist_07":"Nf2fPwaf7RM8UcsRJyjG3lRg","st_dist_08":"Sn1710ZPLM8UkCFEFol9xFfw","st_dist_09":"Ovgr9HT0VuUSKJ7VtC38tSCw","st_dist_10":"WPz8DVK5VSRPl5mVpikxYzqx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IbGuO3rCr9BK3hQMnzvhog679rhLMxypFcY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":948,"st_w_id":1,"st_quantity":32,"st_dist_01":"W17OtdHm2HXr4V9wWmmot6vP","st_dist_02":"3dqaWHLxEEtD9kiOZFJfNqQP","st_dist_03":"AVyJnl8C9FVLiJ0jwothzXNy","st_dist_04":"Ud4t8BuZO7sOVpWIPSRn7IV2","st_dist_05":"nEnz0xjV61FfIcVLnuRyiaNT","st_dist_06":"272kgzgC7Lm79NzlxKgkofqs","st_dist_07":"cwz5tG7eZ35jFjpwVmM0XjeP","st_dist_08":"7AHDiX6upwUKdwP0ekFaAro7","st_dist_09":"72cUcLSnWL6t8Wy0Kemmkdq0","st_dist_10":"azS55ga6yYcK8yWajus8rvuf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Rt7ZPu0QgJ8diZcarPAnoyUu3e5d5HU9YrHQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":949,"st_w_id":1,"st_quantity":90,"st_dist_01":"CfWP6GEA0fDVB0BQEi2m2iDv","st_dist_02":"pTMYJ6v6DJKkoP8849fDHobM","st_dist_03":"VLRfMOjzdQsZc415rBhJ3zAH","st_dist_04":"JLo88ocGdJS49ppaEashzV26","st_dist_05":"onzNVILG6M1gwf70G2T2Vpbv","st_dist_06":"fRJffVsZTGeOFLYWyUv1P7xP","st_dist_07":"RnDEOYHJWy19raRfvl4KO2jW","st_dist_08":"Le2kVzkxMvu1NZKQuPp619f2","st_dist_09":"21YQaGUL21QuCMevuK0vvIF0","st_dist_10":"YSpqKXAnkroS7izd2TjfL9Gt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jAPkm4mKHXtEXpZgW2mSSjfdFUvfh4lDGCSjOWZ2x8g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":950,"st_w_id":1,"st_quantity":71,"st_dist_01":"eujkQTyH02sG4VZhO8o0CsDc","st_dist_02":"8k9rbz7vjzsTmLYnBDUBPgoM","st_dist_03":"V873AncLH8PzAcNqyl0KWMMS","st_dist_04":"5el8SlKvjEEm25xE8QYx7ecv","st_dist_05":"kyPyyDfRu4w5iKuQfsRDtwpX","st_dist_06":"3XS10Xc4FvW8h5AC40YPc2mJ","st_dist_07":"ppWD6kaptRqA96MGgEGDpUAp","st_dist_08":"Oun2mCCDpeLLr3VYaBKRDcld","st_dist_09":"t2IltNc4q1iNLCx7vppqRcKm","st_dist_10":"Tc3oUGCxiVeMVJ0w3uSVq1Ao","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ig3OL3anOQ1LrMM90NTEdrVRXUX7QaL6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":951,"st_w_id":1,"st_quantity":84,"st_dist_01":"50ZazH3YXgmKuoAz3Dg4Fw4M","st_dist_02":"w7QJic0FtJqa6XjbipM70zwQ","st_dist_03":"ioqiQarGVcWnhgH7fjuIv6LP","st_dist_04":"1akHu8IFC2jGAHBk0MJ0bDZY","st_dist_05":"Nr7LTq4YTmaJlgdODhGFBAA4","st_dist_06":"nKEGnBEOVuSlkfTK4391pueP","st_dist_07":"1itxdnZnLHAadx4WvcoM9F6T","st_dist_08":"P7FIYRDbmeMuqFSH2rj6Kro9","st_dist_09":"8DQYZjqAs3YjmBpBMBYLzaXK","st_dist_10":"vHi7v7VgNn3WQkRGaVJmamLC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dO6AYEPtngH8E4ywDHYQEXGHIdFf9cpKiNebsFPoQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739242,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":952,"st_w_id":1,"st_quantity":62,"st_dist_01":"Goaq6a2G7gGy2ng7SQIrmvvp","st_dist_02":"uVypdcQNNvXg1gRYOhbUfeun","st_dist_03":"VOpzXg6E8xGnpU0z6DLa1ukN","st_dist_04":"wmMrc0F2x7uaZ07nSkYRpYGd","st_dist_05":"2WA0VHw72Cgh0AEs2hpHjEOX","st_dist_06":"YCxyCE1nPltMLTLzMxEeildK","st_dist_07":"tvwcxqrneRDnlqJSPVgF1bf9","st_dist_08":"hGU17wZh08bXAdjeAtlXzRSF","st_dist_09":"lS1AUDMyyexq7p153cG8u26j","st_dist_10":"nUr7D8ioDiocaydBxUAvBJum","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BeptVco2w5Ammao3UHHPhCjuSTwDodGYKvZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739242,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":953,"st_w_id":1,"st_quantity":58,"st_dist_01":"B4ovRZJoCqgslUfginp2Rs73","st_dist_02":"jb1T6aSdrwzsNWBAf91QgBKv","st_dist_03":"NmTCp3Ih4QdZO2GgSLq2BqW9","st_dist_04":"TsRHZLd9LgpW4rdfGJ9BQXHJ","st_dist_05":"SVHzG7PhT9MpuKHsWcQTpnvZ","st_dist_06":"gkyYAsu46oVd4WbMc4wAUTot","st_dist_07":"buU7vsFbUgpznX2zvm02kRGF","st_dist_08":"VfbhZQEB697Mc05hkbnaZraI","st_dist_09":"eeIiGEWQu1HzUoPCdNX8zvTV","st_dist_10":"Mr0eERLZmB28ZjB70nqUQpyj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bUzvYk6PhZqsnHvKte0ewRsqQEPPuKArd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":954,"st_w_id":1,"st_quantity":58,"st_dist_01":"93Bd6wiXDewj64rbzggt6TbL","st_dist_02":"fGNYiAv3mSfjgoeLd63snKeK","st_dist_03":"Ix2aHDmJmvD64AGJwi70HlFY","st_dist_04":"4wEEN1DOKFYhHmEaIwpGtQhr","st_dist_05":"5ANogYjwxIX4AxGEtztYMqlJ","st_dist_06":"oTsJGujlN7QX3djwsErdicAP","st_dist_07":"k0w5NCEqVV1OPK5bWq7uy18g","st_dist_08":"dGFnWRYMcwVlQAyk0Nz9DGKT","st_dist_09":"doyFUPh8NnTe1NLrdCb2rHTd","st_dist_10":"zQDZ0AYmppip0aTFwKzHGZ7F","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AAk7HguzilsSOpNb070GODMRTeoo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":955,"st_w_id":1,"st_quantity":64,"st_dist_01":"q5WfHP4yrN64gSNfQsVJ2tDf","st_dist_02":"oJ0lJc1zF4OLToVFwtcFTSYq","st_dist_03":"7C0q7PRvpABW6uLH4wtcysNK","st_dist_04":"SHyrxj5tSj5Jkz4k2YzgHRlK","st_dist_05":"3U7GZR0HUXnl2sv2nRaO1zLI","st_dist_06":"oPixKachgjxUAGTpCqeCHjdt","st_dist_07":"fqSuFYaOP07tkRykRUzA5mzV","st_dist_08":"pStU7L8vkVVJAKe2AgtNDoO6","st_dist_09":"95bXsDZaQezFAzXHVhxsvmJj","st_dist_10":"lwiOZrnnbvqELOLprpbhyj1v","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g3rpH7BhqOp34hzGNM5gt3geNO6oAo3EuT34JZWjSv4kSv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":956,"st_w_id":1,"st_quantity":10,"st_dist_01":"8bhkb65r7Er6Zd66kMkdOuxA","st_dist_02":"HYzKVJuIyWFS5t60xQjQDMYc","st_dist_03":"uJEOjsc5NxTGaOxnYhbL6omT","st_dist_04":"pSArfagxx5GDAyA2bvDXxBWE","st_dist_05":"D5VYfGcrmmyuRds1Ou4FQuI6","st_dist_06":"qZHxwdXlgrNIxuRBKOac4FKb","st_dist_07":"nfL0o8GCuv5qbJgkdq4DCnFB","st_dist_08":"5nTf4emTtTkm5L5302oVUtzx","st_dist_09":"OaUkbtFSrz7ZPApPdcYoyfsk","st_dist_10":"gEEgXGRg9izgprEmFljtyNIy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HoN6ADvNEmumStn6h3APU2R22szAKqiaGJIclJv4Wrx4UUYZZz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":957,"st_w_id":1,"st_quantity":31,"st_dist_01":"Ga0m4GL4TdJvUec1Ej6vSAWR","st_dist_02":"JEeWqx6B7Cpe9C8Do53JchWJ","st_dist_03":"pP3kolXvlAIQqQzBimbhFV0x","st_dist_04":"PcJjOoDJa7arsA28CRG72pd1","st_dist_05":"9E72kKUODmu81Yc6QBR0bCGO","st_dist_06":"fmvGj7Kn60gcbzYa517EyqJX","st_dist_07":"1SmVdrNyoh7kaRxFOvNwSQ5w","st_dist_08":"suV6EuglNflU874xjscqN1Fz","st_dist_09":"Nq3Ql0U9ySU0RLERh2b2tPNE","st_dist_10":"v7csEaHUulJp6enNWF9YSHBo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Goriginal2zOgSHCbZAtXAoRbBdQG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":958,"st_w_id":1,"st_quantity":35,"st_dist_01":"hdixihxWOHKMuihjA29Bpcnk","st_dist_02":"wbeg6ksBojVPdYupQQUG3d0o","st_dist_03":"qeWP7r3KY7HqBzr5JNh4UTaS","st_dist_04":"uHqJZ2HJrxPzFuYKrhzPsbtD","st_dist_05":"DQwSSGOMx2Yuj0ImqSXx6BvP","st_dist_06":"NbLlxKbls0QTMS1VHdslejmD","st_dist_07":"ArxflGqE5s44WYGEKZkdy8Gd","st_dist_08":"dOaIfx9jPCfe0RHYfnIbU4XP","st_dist_09":"hdUj9gGw17MRqhHtTp6SZjQx","st_dist_10":"5hClUDnXkzVJNVWYLpXw9z5M","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0e1tyatBSdNbPYgzQ6r3gwfMVpZkwz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":959,"st_w_id":1,"st_quantity":93,"st_dist_01":"ze4TPo96Yhf8uhHnpi0wqPUd","st_dist_02":"gcngH3VJXJ788ZSD3p0RQedN","st_dist_03":"xYMD5eIIKSXVDdU3R3vRYCgp","st_dist_04":"TKjAXIX7YSpNbCQezP8wneRM","st_dist_05":"MmjvJfXI5sboKiLG8wFBr7Az","st_dist_06":"EBHxDau0hHB71WhIiV7nqXBF","st_dist_07":"gOZNBv8GGrtKEuMSQJYiAZNs","st_dist_08":"QyIiU7PJkGE7orEAH7Qa07ld","st_dist_09":"cUWNu3XxvBjxAEInG7OJtHiF","st_dist_10":"kwVmeLjXSLkizx6OuUiHG5Kc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eAGQ6g15QXaZFQKCId7qdoVYcuqTFGeEyM5AkHXNQPwdtHK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":960,"st_w_id":1,"st_quantity":31,"st_dist_01":"2bmQdqIXIV8e6Fi4zOit9PWh","st_dist_02":"raS3apDxVuTNPQoTqhsbBgzK","st_dist_03":"CN6UiX6sz2inqZ7BzkrYhU42","st_dist_04":"LEC8jlnQNAypnv4pAx6ZAOfP","st_dist_05":"di1kTdVMgdD0zH6LVoUqEjaI","st_dist_06":"hDf58eqSokM7hSoEpR3p99sW","st_dist_07":"ZxOzuU24Qye50Q2n1s4empLv","st_dist_08":"QW3APqF4JG3FDFYgwDc5l5Xz","st_dist_09":"Llqh3nqBT0jDZ2nGgxYtthWF","st_dist_10":"EohDuBwDi6vG0rv14aTPmsPb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UA4jv2ZVJo5BzwR6zEchdKnLAJTcJlsri18T9t9WN2fTXe4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":961,"st_w_id":1,"st_quantity":24,"st_dist_01":"BSbGxKtDJZS1qOujcerU7Eyy","st_dist_02":"pqk0TssZHftLArvOriSwOSLZ","st_dist_03":"3o63OLDCrUKvmhSE4yLc5UFU","st_dist_04":"BBKf8TIfLYBOqZm8x9sDYmeU","st_dist_05":"W5urxPM7rBVXg7Vu59ysmLhT","st_dist_06":"CUr13Owk5ANgaALBVg8EQNw0","st_dist_07":"475PkYX77X6WcYL4HKeIRzEd","st_dist_08":"63HMvq3VsAckoj2JR1Z2Lzar","st_dist_09":"M9t0bLXff9jheHBOjen7nS6N","st_dist_10":"DCUGL2rHHMF5WPETgxFI45EL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"czaNmpFnd6c5kYW8MxLCQ2N3AcAKZZ5Du0m1NAa9jBdmy9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":962,"st_w_id":1,"st_quantity":81,"st_dist_01":"9pXYQwDRcdygIrjBmRcckLVw","st_dist_02":"92QLN8mVkQS08FVfmKi31v5U","st_dist_03":"3QVdxWarbggR4QogQKYJKOrT","st_dist_04":"tTQ4l3aaAi14K4qNF5egh5ln","st_dist_05":"tBKBi2vnoNFctJOGlsIC7IUF","st_dist_06":"q0n1m4RyhY8NjtbCi6uvY2Rh","st_dist_07":"j0IY5bIljDSXDIisZE3nhLYd","st_dist_08":"EeyMSXg4NLEjhh2cS7V5Dmh8","st_dist_09":"WdZeLJp6CXIi4XHCXn71St6W","st_dist_10":"ckaOcJFMj4BUFUW2oL8MwDIw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sezuZfBFu3TB7vZHANOCtBvRQjo725QiyAwouXliC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":963,"st_w_id":1,"st_quantity":25,"st_dist_01":"qXXcAE2yb7BS2nKuXaIRiPFj","st_dist_02":"FTtvSDQRzNgmeb9s2CuZKC4t","st_dist_03":"EJD1lPNk2CqyurumCrNJZxfs","st_dist_04":"c0KWROgn3lIk3YZLBksbTD5X","st_dist_05":"MZ7A84EyjQ4IKSuOnl2hfv3N","st_dist_06":"mk7faGcOQRXpbTCEhmdUPL1R","st_dist_07":"CBZWH8n0R1YAGV7Jc1jHt4BW","st_dist_08":"Pdi5NfiHFiw2nwq65kArfcFW","st_dist_09":"Ada7huamK2WecowHbotEFrmY","st_dist_10":"MyKZctmDWZWZ0p5sq0n1oPvD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BU8r5XyKiXgxrxRrFdelmrURSIZCf7IqfXQ6R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":964,"st_w_id":1,"st_quantity":12,"st_dist_01":"OaTEeQuFXUN0pcOr7Stt1Pw6","st_dist_02":"VTXI5v3OGnBLTovTqonnpZBa","st_dist_03":"Evc3mTVSOeuy32hjf2QwMqud","st_dist_04":"X9rpykTwSze9mTsVfouy1tMU","st_dist_05":"q3ivXQ1Mo09dpAUmJkebEdB6","st_dist_06":"ifxQT0FiNYFcZ7UX9UTpW7Hs","st_dist_07":"4rmnzmVW5vwGI3Eu5BEZGUjt","st_dist_08":"Mc4FVr9O8qTRZlQtp9gAFq2I","st_dist_09":"HCTfWE47pcAu0cfsYchIuXJ3","st_dist_10":"ToUPMXDKGDZl3TCDcMX7uxtw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"quQaPIoSSNjLWg9pvsmqmCc6E11JLwb0qF1W02V1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":965,"st_w_id":1,"st_quantity":19,"st_dist_01":"2QMJy6wjJngC8NFfd91WuObg","st_dist_02":"4ADj5BCHVclhjCNmm3rLDzGf","st_dist_03":"ljnEcKCW0hP2IHBXtc0S3rcQ","st_dist_04":"9eMyGjwM5pCtFvgg83rsN0Eg","st_dist_05":"KmFtpzFWAbRIJfNg9xXCs5ud","st_dist_06":"McBTuwO6kKKuVFg91bnNojZc","st_dist_07":"9Yi0tWIOvHyVn1vpux69ayw6","st_dist_08":"HDae7PxA7SfnsS5d3I8aGbf7","st_dist_09":"xEjeesMq4QLJGFaYg7ZoJVeb","st_dist_10":"FhB22ovcQ9ZRH2077E4pJ1Mh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MrndVdkAIOGqGAOQt9uOKMMRGwIG8oTt3Fbse0O2yRZ5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":966,"st_w_id":1,"st_quantity":59,"st_dist_01":"eh6l4aa1UUhuwKQcpXlaWzWr","st_dist_02":"0GYgBtFC9dAzyum4UR675PWB","st_dist_03":"U0uFPUo1cmns6txkhhmRDX6y","st_dist_04":"7xBxP6f0250TWGMmrt3p1lCH","st_dist_05":"H2nbRTSt5YbFLg2qjxcYwKls","st_dist_06":"dDW2VjoIat8V5ncspYvk0tIW","st_dist_07":"63l7xZxixAEWxjQcaYfuxeJE","st_dist_08":"6ZhADhMLh47oQgYoyea3OzXu","st_dist_09":"3aw2ss0fOdfaZePOBKHMsMoC","st_dist_10":"z89SlPD8nJreVXtzrSviWN8B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"h6Bfx1xMqAgZtZQC0ZuVXFnRlht5gnBVjSFQfk7NSuw3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":967,"st_w_id":1,"st_quantity":77,"st_dist_01":"IyDJl2VZ0XBYa5qeKPlYpLfc","st_dist_02":"ul8mPjzaohMYJuP46nzZk4A8","st_dist_03":"PZsgczjKtPhNVLbcQ1xrfFIJ","st_dist_04":"qUORpbzC787v7FQN3k0D7p6L","st_dist_05":"TM1qMYeJDFHiO4pS5DcfpuQz","st_dist_06":"IFbLCYO8rFujXe9UErs8gQFk","st_dist_07":"DrAJjcAkSfz7YDHOtL9h1Dw4","st_dist_08":"IgsXzSbruzFRFAVhPzfpDcuj","st_dist_09":"BajwP19lpLZtUh6qxkOI5K01","st_dist_10":"oVdOHDEwwGHUp2b4KyYddxnU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7zOM22XeZjAP9b7ZLYx42Cqn1u7yDsPXpQJtANdzdxn207I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":968,"st_w_id":1,"st_quantity":81,"st_dist_01":"EBUuh50qrqmsyHqI5p6gaYDi","st_dist_02":"Nks9apix3Dhmj6deroy9Gj70","st_dist_03":"v4BWXxHnRe6oRa4SP0FChWFO","st_dist_04":"8s60H3SLUYQsAL8cD7UnBANF","st_dist_05":"qKTBNFKLqdVSjLCbmAemztZK","st_dist_06":"qcTMXb8MBeTrUSsPLFjAKntZ","st_dist_07":"Qtl2wcN2oFTkPLDZI1SXLAYT","st_dist_08":"bMRZx6YpAfc2hvPFl7zRYPfB","st_dist_09":"WwRy66m0o4Tw6FCBDKhzhQXw","st_dist_10":"SKXjsRTyRgXDLmYDCFlnDuxw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fRrFpGvQFWOdkFlhzVCpVxMgUbNz4s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":969,"st_w_id":1,"st_quantity":69,"st_dist_01":"1aUFCetaN1X6sSkA8kahKOYA","st_dist_02":"Fj2d2UdUgafbdUPsED3gqKuY","st_dist_03":"cnlhaat2iI6fVk97ihzXgJee","st_dist_04":"Wm3wMnb82mSO6JZevfXA9SXI","st_dist_05":"UHe2AESxzKBhhxtVmLFeUzUU","st_dist_06":"rAapJSKn9lUyUSzYBtqB3yO2","st_dist_07":"NTVTpedADMLTe59L258Z8c0j","st_dist_08":"EyAV4lpk4eCQKiT62rmr1KrF","st_dist_09":"LOsstgh87FmkufvdMHj4CBig","st_dist_10":"u7VtmS0Bbcxu7A7TAVctRPC9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"J4jvhUkBNRELihut3t6jEsYsksmkbKIgzwfDoriginalRgbS62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":970,"st_w_id":1,"st_quantity":69,"st_dist_01":"KrdbKnrbTWGSGJfDdGd3EtHL","st_dist_02":"3vw32Vlv8C3DwMWpuge78Vcl","st_dist_03":"uc1qfgB818BLpv0a5pOUaYsb","st_dist_04":"tJl6CjtdFYhhXfLrejjIXVuv","st_dist_05":"Og7PczHmJ6TmXzWLA9z4MOMd","st_dist_06":"q6IRBCJMRUVZapRDkaafLIPf","st_dist_07":"E5RlsyZmD53jRGBJ1U0FYb3O","st_dist_08":"MrHvjB9i1nWq5A5gkmRToIat","st_dist_09":"QlYhfFaX7OZuo8arqLEeqDRv","st_dist_10":"jhDcDn7JsciJ2uGkpMYuoNU4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"p0V5SSSAGLuORapITYmYoPylSTasUPgo7WVm0K3iEdj3rMMK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":971,"st_w_id":1,"st_quantity":85,"st_dist_01":"NGiELp0ogjPp0pXe2XwLngyE","st_dist_02":"F1bSdb8YT34DwxMHSS5efav8","st_dist_03":"xG0cSoU7BwAlYDMOvF4isVTo","st_dist_04":"p3ef8m5OyqVceF6aouQeX971","st_dist_05":"uVqGaxomI8so2hXeNRbLzMO3","st_dist_06":"GYX3h4zV1bE89TFGCGyXWJ1j","st_dist_07":"8x8Ty75A9XRel96GDU7zjzlw","st_dist_08":"VwPDyZnnu0Jh6WZwNHFXzwR1","st_dist_09":"IPoyr96t0iVUthCHa3NOXTyp","st_dist_10":"QPByTgVYKM50FAj6hktke9qD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KI8W36RY2ZOqYwqAjLcMUStteljEWokIXrpwTPGuO6rWib"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":972,"st_w_id":1,"st_quantity":29,"st_dist_01":"Hma88wTz8LNyX7bCYkkc6MPK","st_dist_02":"7WHu0k0ocoWYEGJai8zjbG0F","st_dist_03":"yWgVOsEZVWfLgH09nU6LtCs3","st_dist_04":"mzCVWh1lLv3QhcLqaUpMfvoy","st_dist_05":"wZoyeoNi9JHxuBND8R02059V","st_dist_06":"36m8634ucWc0wnx1vM7CYYfF","st_dist_07":"2d2QK2vTcV2lDQamaosAKiHj","st_dist_08":"mWAJ0yRNqUFi3OrXg5GrGhTN","st_dist_09":"FyFXJDFqkbX8tmO854RvT4O2","st_dist_10":"Ebc3bFd1YRdJgBOR3nfTCYLI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uaW6CmMEI4QXnQ2u1ULvdxz6eckHuQZBswTwxlpJD4psSf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":973,"st_w_id":1,"st_quantity":15,"st_dist_01":"MZmB1O5zfxPBx7J8lKjEWn7f","st_dist_02":"x7pQFEKcsceX22F06wJOgBEr","st_dist_03":"V0pzLdY6DgZ5JRLhLgJQM25a","st_dist_04":"nwSAR12Yna0cAbA9mU1GYeuk","st_dist_05":"iFw3mQGPRvKY00x2bQjWhcg4","st_dist_06":"PdHJYmcy9YcYrrAdJCpfRKxB","st_dist_07":"AzqSaOzIcEKm6cJLUBM0d5Mf","st_dist_08":"HxviaGrRQlKDQJFiqInLHpkV","st_dist_09":"lMVEoG51xKtPgrvhML7je52x","st_dist_10":"mp85i0YaWR1UQVPFHXiPrSPB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LoR7dxK8XMMhYHc90oDl4M5BZoz8i1xyUgyRM3gpruSXBjg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":974,"st_w_id":1,"st_quantity":97,"st_dist_01":"WkxJMKzDuYep5c0KaYetvAO9","st_dist_02":"wfm4gwnZUHo3eKAAY6dKqvME","st_dist_03":"1W7e7UhP08ejr793CUNxTk2E","st_dist_04":"voC5i1uJmDlXhnK8PqUyyx1i","st_dist_05":"aleBHRXLaOVXokZW7g5Fyr7T","st_dist_06":"TxecAREgr67Ktvai8GTCei8e","st_dist_07":"jjBpek0CGzEgTMAVjfbjr7Ic","st_dist_08":"epl6gPSk0BKVLi8d61qenhDd","st_dist_09":"vOrYYuEtaQSntY1e6Ingyz5t","st_dist_10":"DtyxvxdpWweRhNwQA7rG940A","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"q9YChCsGlEy6BLO9sMu9QUM9BX2wRXWopAbMXIy3pFOi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":975,"st_w_id":1,"st_quantity":12,"st_dist_01":"ENAomcddvimsnlQGSNmRx4PV","st_dist_02":"2Wk7akyu0xTGBODIVXgKAGDF","st_dist_03":"Zuioyc1f7XgRAm3mVPDGRyKl","st_dist_04":"OZBtCChF8c3easklUSvbcblJ","st_dist_05":"T2pJNdWXE7z6yhlsONWyWNFu","st_dist_06":"NMX6o945SwbYKKpX2kDi3FGM","st_dist_07":"1av4iNzPXg3KqxWwKMH4eZpx","st_dist_08":"jFJaGHLPcQQVOieBX8Mcepml","st_dist_09":"SJISmX00o04ZSDL2AYvi3XEI","st_dist_10":"BxoMUQk8YxTp6ofMszqpZePF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"e7gTCgGQUwQJw4suZclf0U9deG6P5j1AjI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":976,"st_w_id":1,"st_quantity":74,"st_dist_01":"mNKkWuvOERRSRYFXx5ALyeGv","st_dist_02":"vghlwzSGzj04WzYDaaDfRkKR","st_dist_03":"1TPxyAzy5Fb0ALEAUo1Wk45g","st_dist_04":"lzG4oGNJPY0Jh9XC4xpSqfQ5","st_dist_05":"QQ5xdlsoC4ZhMFnQ0QawwtgG","st_dist_06":"5bq0M1uj12YN5e2hePqiz8RX","st_dist_07":"CXwpaLpQU0fuSRUjZI4PL11b","st_dist_08":"Eo6dwvpHG0hi8adIJguxdqfj","st_dist_09":"iQruDbpGsHlOGH0e0VaH5ivk","st_dist_10":"4qK8YFElEObYjFdG6jJx0cFB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"j1vTYtvMCwwfiaR7dGn5CXhg7lZ73SqUcwXNsfCVCrsDSc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":977,"st_w_id":1,"st_quantity":96,"st_dist_01":"SWsADezHA19569UdtJxe5X8r","st_dist_02":"qAq0N9WkoEed7TaucsTRISxw","st_dist_03":"GaF3wwLqWu0aalu6XykXhcRw","st_dist_04":"L8XX3zEEauhvPUIAOGfaiCye","st_dist_05":"sGDffcUBhb9Ag81Yr1sVybI9","st_dist_06":"WrcPoz8E2iNDllm15u0quX5N","st_dist_07":"nx8PS18yVEPl0Vfzfx3TDChp","st_dist_08":"gW0NrQe69YLaSkcnJSp9rLWv","st_dist_09":"INmZ28vuDuIAzXBBofXMt6fI","st_dist_10":"7T0S4ZWAk59Zr6QyU2wY690S","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ue53CnPmfR9wcS9ptOtCsaDX5wwYddEhLsJg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":978,"st_w_id":1,"st_quantity":31,"st_dist_01":"B64o0QdFzwVib2b5Klq8Mifq","st_dist_02":"DUAR7bz5r5BrqAbU8b2hBaEM","st_dist_03":"2UwphvyEmG7KHxnNEbhe1toq","st_dist_04":"hjjUub5ll2pi9IFZGkLquEIC","st_dist_05":"1S92rq8D3yfEMjWqZ9DlEpbA","st_dist_06":"ViJEyVhbDQroca9lTpyZVLcq","st_dist_07":"2AcMKLZk9FVy6bc4nkZA8Br3","st_dist_08":"d7NuJ3LdoZlWBYawkeIZA6J3","st_dist_09":"TDL6o3Zi3xUmyJrgT0rERfXn","st_dist_10":"iLNx1xQqAk1jU601kLoKOayr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Xaxk91cww8vTBGcd0nONgbRXiAypE29Vyrn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":979,"st_w_id":1,"st_quantity":83,"st_dist_01":"bvKbLHm2AjWLaN3hF1i6ktup","st_dist_02":"eZUNTJJs3hqCd787rojs7aGv","st_dist_03":"mXJilAY0v7x4RVGl7pw9cwoz","st_dist_04":"mzLp68X7FslE3xZiIPvsNH6g","st_dist_05":"n3jYPsHK03Utqyelz53qJ9ti","st_dist_06":"WBWBrCiCJrKXv5SRgAa3lPas","st_dist_07":"jeO63naruvun0SebctGt2sbw","st_dist_08":"kEKtSYsHNWaa25gj0QhzOZSs","st_dist_09":"x9BIIkBq90k99KCQtrKwDbtL","st_dist_10":"zK2BFQqVV8gC1ScktGBzBycq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7l4wSHKaBBJloAn97U0XE55m4EnY5HhgGojVKDawsCxdC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":980,"st_w_id":1,"st_quantity":82,"st_dist_01":"C4t2BbXx1BJLb1PTQhM74J6S","st_dist_02":"1BYoMcUAAMxV0kyDYoOZzyWv","st_dist_03":"jQpam55wyQ55bhXIYerMA3Ae","st_dist_04":"jf0tCRLXvCPckqTu8xZhg1pW","st_dist_05":"VvR3Y3cO5mGWY7T0qS0sjDy1","st_dist_06":"HDdT1Jdui8dTikmKNBzPwJOd","st_dist_07":"KzQ3CiznzzqJRcxCRlSZ1rgM","st_dist_08":"FuaLZVbmZjNlaBofeAFYeXWU","st_dist_09":"Bm37Ae0FN7nzLyv1XVvAXtWt","st_dist_10":"wEdg9ppyzYJ3f23tVxGj58Kb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mCdaHJk1ipuVVDwiO6yyyHrMYGdBPDXWBF95LRQI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":981,"st_w_id":1,"st_quantity":43,"st_dist_01":"rBq7LnzjonpyKXY3nUHTqCZy","st_dist_02":"1iK5PrgPgv6VhiLynaRRD6wt","st_dist_03":"1ukpdg0Ak1YFaPRKQzPOeHjK","st_dist_04":"dyIIOYukelQN17dmaHJiF33E","st_dist_05":"lDBBFQ5y1POLmBhmHDo0QXU1","st_dist_06":"Ac1OntpvOCPnwzcTS8VrbNG5","st_dist_07":"CweOWhjX29iZn2a039gjRn5M","st_dist_08":"spKTQbzp0BHl3FLu3qdGdyko","st_dist_09":"oVDeojxL2UEIQrJEBBOmhtpS","st_dist_10":"r1CRFSswGmQJtrZZjceHyLqM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"M3f07kPunfX6h0LvxbSqA6TNlmeSNfA126PiUZBEg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":982,"st_w_id":1,"st_quantity":65,"st_dist_01":"3VTNOtvGMXHC4ZsbEMXH3GEO","st_dist_02":"g4X6jjBXoTE6yI02BaHwm2Kw","st_dist_03":"K26OwA89fDiJUuA0Wlc19T3Z","st_dist_04":"lYrJvIyKrnYFgVIZLHO1iE5S","st_dist_05":"qFvQ9jH3dRIfOO5KOx8H5QPD","st_dist_06":"4n5x2a1eqpGUVNXP3MloLGFa","st_dist_07":"kQfYYm9lhVACuuL7n64NM2o9","st_dist_08":"Kl9VRLgbeB99EpxXmucJP6be","st_dist_09":"ezfXtZySU5Le4sQMigtbD8q3","st_dist_10":"y3hLd2tZ3VTz4YEPxYz3R8vx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fjphq2SjMoY0RicdqlAXvycDrZ1XVSX5G8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":983,"st_w_id":1,"st_quantity":95,"st_dist_01":"XIQ0hpvAUWfCbsRK5PesveI6","st_dist_02":"ufq9351Yc6DMAoTdyEpmfMyi","st_dist_03":"XIPcmJedfqiCTLllE1xwTw8y","st_dist_04":"YRGM9R3J1uHb2hKumVVvAg6A","st_dist_05":"rvsnFM2qNUkf85caD90Zf2r5","st_dist_06":"zZStnLRuObuivEqLpTpLOjV5","st_dist_07":"liWuekenrsF7gMCUujvBHqG7","st_dist_08":"nPQ2RZSINDoPxsXc550rt6vr","st_dist_09":"77XMEHbAuOKYQu2eadgSia3m","st_dist_10":"CWqAPWXs3qevQpWWEjJmutC0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jHlHpbwUo4yIfSV9aE9i8DvS2Vtvjmq3OtXALMf9pGxnI6Rhr4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":984,"st_w_id":1,"st_quantity":63,"st_dist_01":"ynAAs8Qjoh3G6GVcfgbloLcD","st_dist_02":"pcbW5v6PVCrmXEf3ngxlcrW9","st_dist_03":"Sy5Xxe9Q7dcnRb09mNT50Tpd","st_dist_04":"MgRBPByPULr1p9ATxp2DiZPd","st_dist_05":"9P2gMden4SZvvuAlCkPz68uN","st_dist_06":"imOpd7YAWDOVftgOWaquoT74","st_dist_07":"ECaFAaL2J1dvxV2a3B2kpEtq","st_dist_08":"0941Js2mNPqLi1qhIsVnkTrz","st_dist_09":"dmoKVFsvzvWHJEUW1oWAlSjG","st_dist_10":"uzQDX2j6XFLCpVB6QSbZWEe3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VwiRGhPxl83wPTnJ1NglyRFMHIpYailxj6AHGWcsdkFE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":985,"st_w_id":1,"st_quantity":75,"st_dist_01":"r5JNr5Xj5TowhMY2asVSPW5T","st_dist_02":"bdiVOeaCRZo97FwIGZuqH40j","st_dist_03":"9dL7ttXr7pQCcljg3KULNztG","st_dist_04":"2MV0Qnnsa9Uvq7nAnUQKwpbQ","st_dist_05":"jDOHvWjahBZ9ysd2jhvcuUIV","st_dist_06":"aBNSh6ROank7XHsIutXKGLkh","st_dist_07":"jUsT4pk2Tnvz3MX7NG8ggD4Q","st_dist_08":"TE2obd7cmGhYL2p7uVxMVplE","st_dist_09":"8rxCzUdTLMUDD6Ro5QcP0yi6","st_dist_10":"b7WycChh2vcFfrvcIpcIrtqg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dsUS5kEotwfgIlcIBpSCTiElRO6vr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":986,"st_w_id":1,"st_quantity":55,"st_dist_01":"IAl5eN6J2ueEWMwOEXvoFXVu","st_dist_02":"FNrhhNWef8vwbcGvmQMJyVt7","st_dist_03":"L5rBdmhzZreZseLrXFozgsrp","st_dist_04":"HpMriQGcwJDMGGP0Z0GTxr5Z","st_dist_05":"M9VUOpNwXVUgsKjGsoEU1YU8","st_dist_06":"ORo4X1clSJi2JJpb95X77QjT","st_dist_07":"arWEE77In6J8ShyISgReXTQx","st_dist_08":"COrcIzIxJ4OKaW71E3KwqqnA","st_dist_09":"IZF4PhOsNYPYJ190m8i5nWAX","st_dist_10":"rj1jsbtNYdqV1tIZmF6eAvAs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g9hexFyREG7dypMFJ8Vyj1NT2JZAqqs0BSdW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":987,"st_w_id":1,"st_quantity":72,"st_dist_01":"sTGRyiwf17HR6H8AcCsf8iFK","st_dist_02":"qZdZSgEmypqYhT5E6QkKKPzP","st_dist_03":"qPTVGvRUCi9IgcvBFEaRhERH","st_dist_04":"FDWeyxaqizVDR90OLBHyR0As","st_dist_05":"RCadbLaTFXkZcLG6FXtOKmoG","st_dist_06":"ff04ZwgzZf3kZiUu6mo13aLS","st_dist_07":"oLWSCG5gnrmV1soAz31iGG4V","st_dist_08":"Cs9hR8CB6MaFW5n1RWKGQ7Rq","st_dist_09":"xJFmIDqRapvhR5kApK7LBDDo","st_dist_10":"UGOoTJzkrxLyceRoDoWBdBRO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"woHuz5ojK4VhHxefSMD4wKyau9P6wPmn0xwQLSJGv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":988,"st_w_id":1,"st_quantity":12,"st_dist_01":"w4IG9AJup9NliwXh11LB6fjM","st_dist_02":"LJByXmFsV0kUJDOH5Sd9bhiN","st_dist_03":"VmwQSvihA32Rwl1bx5Pdzr5c","st_dist_04":"NnCujyvlkmA2nvPLRe3O5Uqg","st_dist_05":"LtW4YamfBgclD1TSEnTcAwPk","st_dist_06":"H4TUFRuSdJnX0OXsR64JoQ6n","st_dist_07":"gYnqhcSlqAUwAeT8pxU6EhTV","st_dist_08":"UjVI1lKmcd1rW1tcdD2VhUFA","st_dist_09":"U8f4R8MCNPdrgWjDiuSVljSl","st_dist_10":"pBHsD8Dv8G23jcBqOZ2xzPzF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MnokOLUl0SSr8FCWTkhZtxHK0qcCInD3Pv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":989,"st_w_id":1,"st_quantity":62,"st_dist_01":"m7E7O3XWg41iwmZR1EV5408g","st_dist_02":"VYwsP2NPjlfgaF3HaBcYMyLk","st_dist_03":"tFkcV4FxxJyekuWaDGlBn0GW","st_dist_04":"Fx8fCFOSOW2LK5ZYROMgcX9B","st_dist_05":"qYuQZam1332U1L5d0RnOnxqX","st_dist_06":"yTQ7ZvRVtN7H3eW4SBlRCbOo","st_dist_07":"eYXW8DgDc1qMHsey9mfjKgT1","st_dist_08":"iSJviyYrAGb8cJ7r2zt4kQCO","st_dist_09":"cxZBSkJLZG5cKhpjVBFW9ANM","st_dist_10":"ZVXecrt4yIDdB8DAtKL5Son3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Aj1W8DDdlfK415h33heY0eaoKY2veOt2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":990,"st_w_id":1,"st_quantity":80,"st_dist_01":"ZCqk5ejSvNLgqqLn4rRy6MOB","st_dist_02":"wmZIHACMUWqA8UcPwUnzPpVX","st_dist_03":"zRrFjaqjUSkNZkkpz4CbBQPM","st_dist_04":"bUCVUDXbfwAanPleNSA1ju2B","st_dist_05":"aU4C38sAyXCe28gijtUBjCjb","st_dist_06":"DjuUZzliWiI4lN5w5sAv3IPB","st_dist_07":"lkOoAiKY1PebbVc3rOaHpT50","st_dist_08":"SVp0gCbqRC6F05mZwi22PoTq","st_dist_09":"4rYNH7PlMBKBmRUGzNyZ4aTg","st_dist_10":"WO8mCkrzyZ0LLIrhHQa2OEya","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"o0ZWzK1FqoFWWdJJnnfYv41wXaw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":991,"st_w_id":1,"st_quantity":29,"st_dist_01":"IkiMzBmR5u3fluUbJcSGyjB1","st_dist_02":"MbZGCPHzJ4YxORDAe0ZTKyTl","st_dist_03":"5yxfqcNPQxSCk74sYIk7hwYv","st_dist_04":"AmCifcI2ItJ7aeZEhl1rfV2h","st_dist_05":"85HK78a284cLrGwrzsRhmOcz","st_dist_06":"rtAfwfiTJXm6eWlqQTPsZxk5","st_dist_07":"2XMY1nRTDuoCdm1JAQ1iLbdQ","st_dist_08":"jBxix9kpwidpNQkjMzTeV3gm","st_dist_09":"rDSNUYLEBsY5dXSHCEojAPwx","st_dist_10":"KqoonwOINHngaWIyJbpZyu8z","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tdYEV5h4X0yzBXSGJBBa9V6GWq2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":992,"st_w_id":1,"st_quantity":27,"st_dist_01":"NGQJLngM0Iht7MO46maiDSSF","st_dist_02":"DcHtQkHBA8i8qY2l0WlBfrad","st_dist_03":"aEoPzaOZdl8Ogtj5jECswnaM","st_dist_04":"oomNSgA9WqmG6KdQZfBx6YP2","st_dist_05":"IscKPKNfH6Ul4TE3RwUsntRe","st_dist_06":"tgw2cqoKNWru419FvehNnwWv","st_dist_07":"9HS6yaso1JQDxhLTV8KNCbwF","st_dist_08":"NpH1WCFW0ymnYOdScx8utqhY","st_dist_09":"Og56RH9kp4XKtH9C9j6TaTaj","st_dist_10":"4j9tmVF7eW6bUZI14InF2E0b","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"x0oXGl4qucOlcnuWU2NoaXhjPcBqUXDaBga6a61wuBJ8c"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":993,"st_w_id":1,"st_quantity":40,"st_dist_01":"scayTKF7xCcYOpSV7O7XNt4F","st_dist_02":"GfWGYNHNJbCqF3rwJ0cuNnrm","st_dist_03":"iexELs0Yu6qPriG2xLZXF1YE","st_dist_04":"ew6XPFiGeu2fAXk5TSXC7S2Z","st_dist_05":"Y428YOYmOawAr3BYhh0Dye9B","st_dist_06":"jsGtO3xGKtKPvzVHc2Wfi6wX","st_dist_07":"2w830OYW0uh4J5eYm0v7lAne","st_dist_08":"qQcUt1aSbGodOWIjDbEHPhvl","st_dist_09":"cT41xMYS5UqJE7BdqH0ujckQ","st_dist_10":"WFGGpbg8M6XXdr78QXhFQmPi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aOtrOLjNHI6XjU41lxs2OqAbgWQZ86rFide5Pw6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":994,"st_w_id":1,"st_quantity":64,"st_dist_01":"hyfYQfFk6fNHjczED54gaRcH","st_dist_02":"lkf7KNmabYeQRFwSWICwUGrl","st_dist_03":"mCkkoVzfcGTrbudoe5ebuuXu","st_dist_04":"4cR3JCsOi7z94sl6KEKxLZTE","st_dist_05":"e839BMmSCJEBv2TCl9un1DMK","st_dist_06":"DkOSgu6nkervOnLJeXr6ZYkb","st_dist_07":"zT0NFYCwWPXZexnGXqpL01w6","st_dist_08":"eijyrisEH5KEudPisSqn2swg","st_dist_09":"zT44CLRA9xGxuCB66bYmCj1k","st_dist_10":"s5ijIj9snJc3uaLJn7mLP10O","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lDLDL5GESxenfsRFSJgaogesoLFq3Ha0JiznzsK79bE8f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":995,"st_w_id":1,"st_quantity":90,"st_dist_01":"PdY6tByBhk6E1H3x5qOCfzUA","st_dist_02":"gZKkjhKpKYH6ymGggLxdvtbp","st_dist_03":"7LV21Os7Zzbrjh2fqxonP07V","st_dist_04":"Wn87lyRfJ92yll9O2t8drYRj","st_dist_05":"Za6uRqsGk9ounnBrVwOpwjiB","st_dist_06":"VzSNvNG6l9IrDNlY2gg2tg1n","st_dist_07":"JXcQnRY16jF8FQNshAxAiNPd","st_dist_08":"MTyfdRSiPPWNfSX7TlX3SKYR","st_dist_09":"rBrztP0zmSPwqeRirqeiVrcg","st_dist_10":"D0Uqi6aRHBWIsicK2q4SJqLq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PdCVQRlYGdRr3QeUhdysktHStNkqc8sSHdS9igJI01K1KQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":996,"st_w_id":1,"st_quantity":25,"st_dist_01":"0vuC6o98LbWuV8aQ204e5dnQ","st_dist_02":"GkcDXkLdCR4K2huOHI9bLAzI","st_dist_03":"N20XBnGCAc6PzvkDZLYc5XGo","st_dist_04":"BfT1F6oVbSf2ACQAxA9GebKv","st_dist_05":"2dLRepU7v9GVAXDEJsPrcVkK","st_dist_06":"gw83sYJwe64jj2nYlwDnRUoe","st_dist_07":"FbMFGWFlQzXPo3xvbBl7ybQB","st_dist_08":"Bz3dQbRgFpmNhSsDoVgqZtUD","st_dist_09":"eTpWXyIZLTH5zVprIbC3rWP6","st_dist_10":"zuqFRO0Yw5PBqLbBLsneAxqt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zOjjwoiERmporiginalUFJUFEBE2YI8H4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":997,"st_w_id":1,"st_quantity":20,"st_dist_01":"P1cuHsZ13RCIBtvyR9tKFTSR","st_dist_02":"adztafIwrCFpYdtiCyjhOY8F","st_dist_03":"bKqLsRys2SibS1ClxapJMxGE","st_dist_04":"lyBTqJ4B3ijFic5dNfoyTGMX","st_dist_05":"OWzz26F4fjT2gdOyFe87an2y","st_dist_06":"40VeFKo9aXMRhRjdxfuK6nPk","st_dist_07":"jhNezoUwDm2hDgwMac5oZ7Fb","st_dist_08":"wplQRs66Rqu9F1eKGeOBSxHk","st_dist_09":"v9xAVTkOO5HUWZk9B2l00iOc","st_dist_10":"hsB53rNv29s7MUBZGGqrJCLT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zYDlnCabcUiE7YGe4mEoWIGM7nJ7dCgtFHRggA6pzpJwn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":998,"st_w_id":1,"st_quantity":98,"st_dist_01":"exn46q58xq0HsgINipEnUCcL","st_dist_02":"k5qWA78KxOEseTnvIWzhRrPv","st_dist_03":"K3PBygTLK5DD7HLtSIvyn5HK","st_dist_04":"HXX5q7THdlVWFWyAUwdSEM08","st_dist_05":"87ucntcgnfAsPDpKg3Pl7GVO","st_dist_06":"IldtoOOEeNMYH1EaiciUBSjL","st_dist_07":"GOrk3pgC8gu4L3DWyjoMuOa2","st_dist_08":"LaUMH4VorNgh1WueJcHpkyyq","st_dist_09":"XF68uCn9UfU51bHm8JoupcrJ","st_dist_10":"bEcwasYxBh594v49LCmfxj3d","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"74kQ3s2HOTUmZYypywGrqNA1yswzlSLff1Rzy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":999,"st_w_id":1,"st_quantity":49,"st_dist_01":"AAONTjfhOV17UB7cUNeGOmGX","st_dist_02":"WKrsC0WiXubPMyVCJ47pEsen","st_dist_03":"NA4zwImaXcpwu9B1me0r8IXP","st_dist_04":"bd55H8uQozrDYJwmwwPzPKIy","st_dist_05":"fLD2c4bBY7m764Q6us6lcOrf","st_dist_06":"t6cHen3WTno4PTpwNouYKbA2","st_dist_07":"j5s2ZGFtHU2VYirJGvDvrCfK","st_dist_08":"Lx2K7NdZIFr7oFSbbMXFwDsq","st_dist_09":"gVEFZ3S64dVfN6CeSx6Gqupd","st_dist_10":"AktnhsyP185EDWsSiRbrhMKe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jMpBXaVc64l2BGpMheJz9Jf88RTcIN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1000,"st_w_id":1,"st_quantity":61,"st_dist_01":"XOU8jp7rMmuYLbNo0HDM34aP","st_dist_02":"WnCW0dtNRgMZJAu5pZgleh91","st_dist_03":"TNIWJRkDGlJTJlmrmnOmNPQb","st_dist_04":"FWLjmatLn7N4bIaNzxsB10py","st_dist_05":"m4yGFQVv46dAW1Pc16JMVUaS","st_dist_06":"i3N0cQs1fqDVAdcWGPADyb97","st_dist_07":"vaapVaNrGZmInn7p2lkrZjRu","st_dist_08":"HpJhSgpVgwO9ESlBaE7GLs9T","st_dist_09":"EUtTJI4dtIKRWxfaIwlSAGA5","st_dist_10":"q4HOb1hDJ5GMRyBtO74L2FcF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5c5XdaGukDULdhEZFfq49djhN2goe8rZqLc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1001,"st_w_id":1,"st_quantity":15,"st_dist_01":"YI1kCrOjuQFoRDY6yitfkcxV","st_dist_02":"jJVoBsht52l5X2qkn5fjh4g6","st_dist_03":"boBmRuNcORJjZQw95iOoL4Rm","st_dist_04":"aiVZ9rSvoWGlRn81NHuky1Gm","st_dist_05":"ZblswIeZBUkeVmi9h5UJCSDB","st_dist_06":"5lsxrURtTu4qgmwml6fMDIZ4","st_dist_07":"OedtZ5Z2ApYjSvow6vEM7354","st_dist_08":"VjRrnoUOFLXlki1U5yrb2lvM","st_dist_09":"1QfllcKz0Rua7aRtRwtGbScC","st_dist_10":"j6h1drvTGmnEC4qy5ZqM2nRt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0MR3kGNee4z0o7m4mmPc3HRU3O4zcTb9qIQ7RxpVamFOl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1002,"st_w_id":1,"st_quantity":29,"st_dist_01":"RRG7SIp099uU1NunfxZTc5ym","st_dist_02":"qrdZdhyL3YN4HLhja7kfB8D0","st_dist_03":"XWbx7uzTZWAJh4Z3USqf1ejW","st_dist_04":"pA7mijqtR5KKB9DpIsxAvJkU","st_dist_05":"CzxA7460RJnrcNwJmbWLcixj","st_dist_06":"jyDH4sC1pnxJCIRPViVLyxdY","st_dist_07":"fpRXrZWYekfKqGQrrYelvWA0","st_dist_08":"FczRafcQTTo5pdePDWz5xwZ3","st_dist_09":"0I1R375rRmRoWgkJuo3A2Dha","st_dist_10":"wc73BA1uiYOgEtW4QuGVK6iC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"D2rLJ72mgZVET4nCuH5Og3zwXKYOHQCpuSzYFthONYU1m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1003,"st_w_id":1,"st_quantity":20,"st_dist_01":"DiNNU2FoN2uDYAw7zAsgouxF","st_dist_02":"ML6V8n0uMEQXIIOZgizWiQ6I","st_dist_03":"4PIt9ZHazpmxjGxhO8IYu7s8","st_dist_04":"79q1aOiUko5188DFcWA05MyN","st_dist_05":"pwzkF0Y4J4o8MbhTLxq5IcDE","st_dist_06":"G7KoDwJUD7xK8MQElv7ewLlE","st_dist_07":"GeDP0wYFEL3kjS7kvj0NQWAs","st_dist_08":"40WvCNg2jCQK5ZDkoQn3HpXu","st_dist_09":"Uo8h2VPG5rKuzQtKMuRafBf5","st_dist_10":"JXMIhXSefOUIVwD5a5ir46b5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FisxfP2319CxByARwfWmf5vgDZW0q2rhpCwY5stMz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1004,"st_w_id":1,"st_quantity":51,"st_dist_01":"DB3qcSza35pOBPJh4RTtC3ls","st_dist_02":"s5Lf6EezVkGe85IwjhTLZaOk","st_dist_03":"UusgQJS6udPtLHNEmZsQaYZB","st_dist_04":"jOMUVmQTuaU9e8dRvDzse7G4","st_dist_05":"yVn3yQjYeKHIGZBQw46x75oJ","st_dist_06":"JKicIBpE0cGm5rys4Hoyop3D","st_dist_07":"kxSP4YLT3icJO01vaImD8GMk","st_dist_08":"5w2OIVMcw6TF5d7idsF62bVu","st_dist_09":"Nj6vD7aPzB1XRG9990GeepLI","st_dist_10":"zWTDB26HkkLkJTzDGKiwGckF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5FN8LLMn0MXYfIniTUpgcwEVTnXXdHAbYJK0RFApOqA5q5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1005,"st_w_id":1,"st_quantity":92,"st_dist_01":"0PzU7MqaPWMGPFVQdxGvtWuq","st_dist_02":"EXpT9qz8t0ucST2KuEN76wP6","st_dist_03":"yGOZB8AhCKoMTF8jDs9CZAr9","st_dist_04":"ZhFw2sYh1gQG7z9821VqQv77","st_dist_05":"eIsdTAekZzlgYOSTr0t8GOU8","st_dist_06":"qI8Lzj3exRoiLFH0gMycYnrq","st_dist_07":"J5jejMYMhMFhvfrvxlusmAVH","st_dist_08":"sOtzrVP59Xi9lCCCnHMYRSdU","st_dist_09":"VKkFAwj2CgQtEMGeNDfpFXhs","st_dist_10":"8cB1k68SN2uHRCuEZmdjk2tE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sBuDPF1qbosdqirX17UuhgXdrsZ6tifEXZyPPWQUGuKc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1006,"st_w_id":1,"st_quantity":77,"st_dist_01":"xx8WYLQymVtbpeHa2PIhv9ZJ","st_dist_02":"vrmqreTYyxDmguxZLGf5QCvp","st_dist_03":"rJYdnrU7kttpCBYWn5nQ76mj","st_dist_04":"aDtsejLzza0M5er5ba8DM6ks","st_dist_05":"XJotEfAvVIZryokDQen6DOpB","st_dist_06":"CuP7Mf9Dcb77BhlXICFlsVV0","st_dist_07":"HpZ8rKgNR3nIQNo6cR6NSyuB","st_dist_08":"UTHh3mpxa6CC9dKdVlPSIxY7","st_dist_09":"CrIkWrhdDHONy9xTesqcQDIO","st_dist_10":"DqYjgpEyAJlOC8UNsRdltOKe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"u7W4UIe7Xzmn2eJvRWaYTIKE7oN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1007,"st_w_id":1,"st_quantity":10,"st_dist_01":"6AEplgbBzMcZLsaSbGnn9GoG","st_dist_02":"bdlqUTYIv2mdeFUUjtfbeiD8","st_dist_03":"JJ2VsTSRAecqEr0K9lNy32JZ","st_dist_04":"Y9qHpADJMzRYcw1WmdbKFzVn","st_dist_05":"ZCtQQw7ZVZIfSBOJBYtA3Dud","st_dist_06":"cp9ntJEIVqhMs9bNfmddmbXf","st_dist_07":"Bj7Bzyrv12SU8s4jNlP8S7Lm","st_dist_08":"oxvS4dfeWgcQuFKG5NXLW45I","st_dist_09":"8r1Q7ikJrTZUGmday9WJx4HG","st_dist_10":"bPW7HQ7BpMw78SwhimvlnYHD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v7fde2ApB94zwymyWtOLkNroriginalM5q7BG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1008,"st_w_id":1,"st_quantity":73,"st_dist_01":"PeWjlwDD6XvCypqc9IfKVCp0","st_dist_02":"DJ7Vn7i9SJcQkYG7cqcjVZvW","st_dist_03":"52y7cP55xdK82eqGQRZJhnvg","st_dist_04":"sRZO4GqwcOdSDxVt7ApEQjXm","st_dist_05":"jNLsixBTR90T2mdmQTjC0Xek","st_dist_06":"RWBDGbxxWdj02RVBI05pMTl8","st_dist_07":"HXUZ5SYOCjJR3eLMbdmrZQBU","st_dist_08":"xydIXOGtmVELbq70bLZPVBiO","st_dist_09":"hS8HcgJAlUAMQwjepNf8uHno","st_dist_10":"fFsq0ud82daI2gxu7qZfp2UN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0rbocovrPXEaI7B3b4SxUuQw8Va67uiNU1C4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1009,"st_w_id":1,"st_quantity":98,"st_dist_01":"ZsM4Jkv375ZpqH2xgsdwoVwi","st_dist_02":"raq4wHMsU4y8yIRXna0IL8PU","st_dist_03":"LvXFOmVYo4rzDK3TtmiPeZAH","st_dist_04":"JJerLCTxGWphSW8kctjwxOym","st_dist_05":"pkerGReBBKaYgLwj0mm4ntpT","st_dist_06":"nPKmdOSISusdDchH0rDgQb47","st_dist_07":"OCxBeVlHVIIzuMnBArP48aAz","st_dist_08":"UT742AKHe7bEHIIWO7jR2X6s","st_dist_09":"9YSfPlKj9EE72JDCKazs8NqM","st_dist_10":"Qy6F7RtHSMv3G41JlxJTcw4i","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fPxu02WsMo1CNH3I4Uo1QMZvPWaQFN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1010,"st_w_id":1,"st_quantity":87,"st_dist_01":"qrMFVAyPHlQEpLKBlNUXqsA0","st_dist_02":"iJ2aZMrhhnGZTtuL8A5DXEVv","st_dist_03":"Z519CYrq3FMhjgc8aSRTMmNu","st_dist_04":"PWBhmRgkbMsAPvFtzolbX5K8","st_dist_05":"DURsTIHz1rRwJvFulzkQoDCb","st_dist_06":"KVxFpEAPDmqwpI6z4ylRWO7E","st_dist_07":"TqKbXo7Jyu75k8SvmZPXmFcA","st_dist_08":"tbmB7bMZ9d5wfq5JJRumNfmG","st_dist_09":"I1WO4hiCSQJohdcaztVARsJH","st_dist_10":"yXoPAcQGXr7DXOvIpg0NBA79","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xU8iFDNSeLwSYYsOlZXWzK6nAxWrD31"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1011,"st_w_id":1,"st_quantity":27,"st_dist_01":"zMuKY6ZvNyBO93QoZtQ6MWCV","st_dist_02":"bFsSXEwrP6ntiGvPvVBN9UxM","st_dist_03":"XTtlaftkmsb7kLXX0mughFQ1","st_dist_04":"EQEL6UACLnjm98EUurPx2dsF","st_dist_05":"yYPs0LVXZCr78PWq0FQ2gdt3","st_dist_06":"TbbSzd0QErlxd7PXD857OD4s","st_dist_07":"DJB8ufILY0tn1PXxI6pXnzDV","st_dist_08":"oLXIHM11nVwjCFrVIP4Hl7Su","st_dist_09":"3KpNkYMLr9NSMqqLsuKrYsCL","st_dist_10":"dhKzNJwy5kGLQcCeE9j0kFTs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oKL8QR8KF91SajkVZ6QrZgJzFahxYjoudtaZBGcF0Wd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1012,"st_w_id":1,"st_quantity":62,"st_dist_01":"0Fno5hQpaboW4mmuUtSOnFSD","st_dist_02":"WrB3YSnfZ3CAbYujAhnwU1Um","st_dist_03":"d4LXfXXwWIAhq6CbGMunULWy","st_dist_04":"N1VHmxROOWov5BBWQ4p2uzci","st_dist_05":"BeGzap74FshmhB8qJ94oLX0r","st_dist_06":"hhcCTo2KFhCj3TJkTFLYreaQ","st_dist_07":"CmNfQ1SfMoATpRdcuhcKpk93","st_dist_08":"yIg2f6kvBBEctWmo8i5ATOWt","st_dist_09":"nOK3ZJLmFqVoE9lUtmlu6AcU","st_dist_10":"RC8rJjdpElY4ziYPm5HTHAuM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"m0cDpwm9731Z7Ms2originaly1suh4IGSrFPsFW6AV31"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1013,"st_w_id":1,"st_quantity":34,"st_dist_01":"slkkKIKsAG2O4BMMddBQbz3g","st_dist_02":"oa5CZKYSWO60q47wROZ6r8OT","st_dist_03":"0dsrew75SlTZC7SyqDbDvgEJ","st_dist_04":"3lt3KsnJusTYCrCt7LiVv1G8","st_dist_05":"dki0fclXdijTu8JyNrBu7peL","st_dist_06":"agRiRxrhBcRnQD9MshDshgEy","st_dist_07":"7LbdNWTiXNOALK6szbVn10Ty","st_dist_08":"kB3OIE4r1qQUX08KQENBwMqF","st_dist_09":"CcleagjhKhcliArvl62ptapj","st_dist_10":"WIWxoFBTw2V6UScZbniQmYks","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ulHWitZ5eYXdI0qWrwCeelwu43FrB5ValMdmE9frchmOscqYke"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1014,"st_w_id":1,"st_quantity":55,"st_dist_01":"u93n04kpte6RvY3Ij3tNqup2","st_dist_02":"QBCTcOe3gsZ8Ni1dfrj5nEeW","st_dist_03":"VU9mjRGn4D42EsnfMcCYEz9G","st_dist_04":"2Y0SizHsJDlg6clogbXuGHlo","st_dist_05":"G2iqeVOJcXRlD2XqhHENX7RT","st_dist_06":"HXYidos04fw0YDWAn2ZAgwm3","st_dist_07":"pyROinXnlfVrRlqWo2EQPcNO","st_dist_08":"reYZ7YFP8bLxRsHT85NF0m92","st_dist_09":"oG0NR6SBYixzXXyFEJyLxKlN","st_dist_10":"8SxeRJ8uJwVo5KJhxldHkbL8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Kmon5KTuHdvE0zXBsRDnKCoIA2pcX35zA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1015,"st_w_id":1,"st_quantity":85,"st_dist_01":"XPyRoOoBQCVPPGvGLDd4Ukqo","st_dist_02":"gTBEYRZAukxQ4y7JIbA8D56W","st_dist_03":"tjyWaRLeRTtIlPgn6dkwzzTk","st_dist_04":"UNNTgiWAXHZMxecEaTdQBNVU","st_dist_05":"lf9RpgOTTsVOsn1Lu0vq4eDg","st_dist_06":"NtroqfL3zzbvApxxDlInYzvi","st_dist_07":"NFLxurNFbRjOsruqoM9Z2UR3","st_dist_08":"n7kDdMfF2wsOF0VA1Ag0UwQG","st_dist_09":"vdkwlY7lt4aFBm3B6rFv1pqA","st_dist_10":"QSgQWZ7MnDG1qRkJiotnILt0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pNnTFfAHEZpR3NPfUEb7cc4QWLGkBLqs3pNv7SwzY5jJHon3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1016,"st_w_id":1,"st_quantity":43,"st_dist_01":"ks0zc0Yld8TUrKFv7LX8wJad","st_dist_02":"jSgua0WAieb1gaQr7ZVb7KKB","st_dist_03":"QBzyw48DwAxW6utfQV8ctzfU","st_dist_04":"EQfTZPhLQ4fccPAWoebfQ2Gr","st_dist_05":"Y17HvISGMkY4QUGsazIrFJ8T","st_dist_06":"xWdDJC05FyPwLYmrIvPPUGM3","st_dist_07":"KJI01jCJZWVjpXWK6fiVkAxw","st_dist_08":"tWm98dDZKPKixxPXVzbQpahk","st_dist_09":"vwrR1RCePnHePWapYCQ8MlVN","st_dist_10":"0kFPFyjWYEQRI7F8ZXGfuPil","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xlJDAI9cRUoW0Q3mzgg3QtZsGcbpXimZznCWdOI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1017,"st_w_id":1,"st_quantity":92,"st_dist_01":"FVpWCDs8YvgRuNlDar5CkcSc","st_dist_02":"wlTzdhaafNeDmvE72YM4QX5H","st_dist_03":"733YTg8xgrBVTvvrfFDsbPPF","st_dist_04":"QOSKf5ffzBZcBt8kJdOwNzNS","st_dist_05":"5nOvstKQvQb15K6aXzDMd5kI","st_dist_06":"JqWNdyTv0pedrHZV2GA61zJx","st_dist_07":"NdvxIPLtPhce6eaY0mvyo11b","st_dist_08":"SvPWoerieF6khFm2UgY5ldUW","st_dist_09":"GmvMRorSMXJVfjDpFlWr8Z3u","st_dist_10":"R84L9kctUyEbYnOLFdbx1Y5C","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2vxm6RCxXXG3OlWCpRVPXXf2AkW7QrbxW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1018,"st_w_id":1,"st_quantity":75,"st_dist_01":"WJjuGa7AXk9C7wNH7WUmkntg","st_dist_02":"3XF5YfSYYBAYMKo99TgAzcAT","st_dist_03":"cgkdHuR03M0ZdNaqESJVnmGd","st_dist_04":"HyKrOGbSAItGfzMSLFnBIfcL","st_dist_05":"cZI3gnTZmNKQqzBXcQwJV7BH","st_dist_06":"CYbfLRwDMmjy8aR9u69wTwYh","st_dist_07":"xbSfjJwqfQOffsBwHTRAVft2","st_dist_08":"LiROYELAQcHoc8hyZZGZCtL5","st_dist_09":"BidKRTAU2pxN24mS8REqiIGp","st_dist_10":"7O6MmtGfUf3HffGgLBuQgPdk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GUsXkrjjaRPb14YI2y7w2MTuDlyc9nSsbUpg7lb0A"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1019,"st_w_id":1,"st_quantity":59,"st_dist_01":"quJTQX466Ga1zjYrkX3uIsdz","st_dist_02":"XkRK8do1hFu04nw1zScDMGUF","st_dist_03":"hVkTgxi4M8DDnyx35QVMnEGC","st_dist_04":"5mWAJ5HAa1AkZnjp5tu5kPxy","st_dist_05":"BPUy8Xl04B8clEAxLkimD1YV","st_dist_06":"M1R39qM5FiQreDFb4pnb149A","st_dist_07":"EoGAVdm9mt167UUMPWDZ79oo","st_dist_08":"iRO4o8vIv0bITf0UbTruDNjb","st_dist_09":"nkU27P8jJ8la9frEqxAUpzit","st_dist_10":"nsqvxwj3ayvd9jKRYDAEzZ2B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rB2c94VdVSviblrbIbF9sPgeiWh9O6i8yDtRG5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1020,"st_w_id":1,"st_quantity":72,"st_dist_01":"QuhhCbXJcgCvRZnLqNckxPPH","st_dist_02":"yhpi9OnD9rWFUEakfXRrFlpU","st_dist_03":"Hbom96zJdWUxZNC0ZpsqCCN9","st_dist_04":"5mIb5alIZie6q4GCyLBsjz9K","st_dist_05":"PFgKIkFR5CqqSeKapFdgHkYF","st_dist_06":"jG0CXTlfctQIQSBNRy8OIY4j","st_dist_07":"xjO6zigxxv6KXlklmMfB23Tb","st_dist_08":"Yv5nRwFxtzm0D5Mg3gTSSUEl","st_dist_09":"0JRxemGnaKSrsDRIPQJAVT5Y","st_dist_10":"sKfzMyXZamftPXnpgEo0B5cM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WGV5WlYbmuhcrscC8Con2XuwXp9gjb10Dr40LxyAVSMyUuoiTg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1021,"st_w_id":1,"st_quantity":84,"st_dist_01":"IL7YX3dlimJaEnBOPNfG7a4N","st_dist_02":"fjZjtnc1w79FQtAGZG3Nitc7","st_dist_03":"w4sou5HqKiqFTUkWssUfNIiS","st_dist_04":"gYEjae0mMMGYzKHxTc7RiEGZ","st_dist_05":"XtBitwGzs91QOJWf9lY8Sf28","st_dist_06":"qG1MCDyaUp6qJ1bdxtb7gcSb","st_dist_07":"dRjRG4fZzK106uosw5CaTMAj","st_dist_08":"ajdgAhOdgSXjS2WULHT1IE4a","st_dist_09":"tIOO9SngmfqTzKokffJhPk8c","st_dist_10":"skvwy6yv5sanBhTEEgxNfgcu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"riVFpxBwRamP4qpKzwj09xaAWpbLOJQ8Tt172qWYTARCfS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1022,"st_w_id":1,"st_quantity":14,"st_dist_01":"sSNqXKPDFDtWEgklpZmdkJVi","st_dist_02":"gXjUEUQmeRvwenQxJBq2QNoT","st_dist_03":"NRM2D64TkOegDDJoL5GfmoHH","st_dist_04":"fCUfVdWvrVLnovrOLNQqChKg","st_dist_05":"1dmaNreCf9nKyDL0cXrVH7GM","st_dist_06":"Z9a2Y92J29VowEHs32LcgDCo","st_dist_07":"j8RKZFNM0u1x1XxZWucZswu3","st_dist_08":"cqtwcbIPO91MdpeXoYQ62VPs","st_dist_09":"ohQ0llwE0hyYVwvwZxi9qELl","st_dist_10":"jHHtCH0tnscZz4ZYquezQPzA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SgQz86xu6zjaoQkucyK6qGBNrhGbCkTvFU8l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1023,"st_w_id":1,"st_quantity":37,"st_dist_01":"7C3f6tW6OobFkDEGIkxOxSaM","st_dist_02":"XXdEC1awAGSKCRnHRQvwgttA","st_dist_03":"ov8Dg0hpyW42xE1LL5sE0Vxs","st_dist_04":"XaRaG3bLs46wyJbT5P4ORohB","st_dist_05":"oGGbNvG4ubHvT1fMpRrTZRue","st_dist_06":"jcm8lmRxeHCFGU9SrXiXTPAJ","st_dist_07":"B3ZInITtTxzyeGIdv5DXCLjq","st_dist_08":"Eh1drDarpk0MtS4g6uWHmuFv","st_dist_09":"Bc0R4evqZjZDmBTnp3CPVAGh","st_dist_10":"gJLOVHJ2ZGRamCgysfmq6ELm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xLkWsKk8vYuQpABjKfhetTpxGRDu3fyTZx9P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1024,"st_w_id":1,"st_quantity":52,"st_dist_01":"44nD3c4MypMGThl2JwR49FwW","st_dist_02":"O1ZGxcR5ffCGW6MYdUrcC3wP","st_dist_03":"r0uAelh20LNySyjfgc3gd5x8","st_dist_04":"7IMnJrdeYmdukSqs0GVIFvVM","st_dist_05":"BmOGltfOqtpuDVB1RKdVwy8S","st_dist_06":"kuWjkOE2RCUhsvn7clMW0HHv","st_dist_07":"Nh1QaJE6ag67w4K4uhER4v9L","st_dist_08":"TsCfisIowBUShH28ORt4uhzw","st_dist_09":"DLD7eCpOgyoEKOfdmhstHNOv","st_dist_10":"lq3UfpfyYrouxVlqgKv64P1t","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kLYgd4X8iqq7QaGVBglrE6BuylDbVuKn7nGBELJqp5g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1025,"st_w_id":1,"st_quantity":34,"st_dist_01":"BLd42C9t0UrIYGo2I8eZ8GyR","st_dist_02":"rl4ciGgxrEcNQMB9bgLQDgvU","st_dist_03":"e9QWieMENgrMyN1Vm6XXNzbA","st_dist_04":"4N4bKyfmxYIE2t58gKQsb5l4","st_dist_05":"FywneepIF6jvX48beJIEcpC1","st_dist_06":"MkQAVCHJ2DwSbbPBeWodhfob","st_dist_07":"NllnZ05wnfE77C0eXsxlhuRY","st_dist_08":"7rXxyuuocVJeBr7cx2J2JqOC","st_dist_09":"e4TtqjrtFOdBUjC6h6nyIUmX","st_dist_10":"qKH56zBN61iYqPT0XQaOjfMZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Mz1s4097yA0x5Jj39XZWCXB4T0WGmFXYigC2T6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1026,"st_w_id":1,"st_quantity":60,"st_dist_01":"IcEsy6A58OxYeT6xagNDbNzU","st_dist_02":"VgC93SuypHQHk5cFWoZO53bx","st_dist_03":"QUGnZQmREBaTIcATQo3JfebZ","st_dist_04":"8yL0n5Tjlibm30mjQTJ4NQF7","st_dist_05":"wQEn0IvgF9VtuJpvUmz9kYiF","st_dist_06":"QqN8hHv8oVwWBamOBDEeKps5","st_dist_07":"UXRbxH0ad64mfPlIcoE2D6QB","st_dist_08":"J7j0YcFz3zBnSSYOwxNyCqXm","st_dist_09":"2ehQMbbDaLC0WarTm66d0Kdx","st_dist_10":"swqP3oncOzcnH7rV2RI1YiW6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EMeHz7sKrCLGoWGjaspSp7dw98Uuhtifh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1027,"st_w_id":1,"st_quantity":80,"st_dist_01":"5QQBHF1gutP4oboSmsDbuWlA","st_dist_02":"NgbV5UxyNQXgivVOpepDMcLR","st_dist_03":"RlFiM6yGL4NQZ6Gx4a7uKtDe","st_dist_04":"9MwfWhHzIEawYioH2UMlNG9I","st_dist_05":"yJPxtBZKjRzPINMZ20yk5Qjg","st_dist_06":"VIZww2LrwBsLjELbqKELFvCK","st_dist_07":"cKN0tYVGD3CfN29Cvzo1PLcK","st_dist_08":"dz8Dzl9O09ukkbD1DypfkVXv","st_dist_09":"5qGlx0LSjKElQaDRtPupL8uf","st_dist_10":"FvwWdUZWnOrGRrh9EG8YDzgK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"24CRAmsXrePIj9HpRh7gZLoriginal"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1028,"st_w_id":1,"st_quantity":69,"st_dist_01":"CbbaZSP7Bp93NmDorRcMhH5L","st_dist_02":"JGo0tPrakCWCIj8GWNmxP9fI","st_dist_03":"NJ1KxCyHRaMzbykQhkzqg4Zr","st_dist_04":"GgsXGnEP5U6Ad1W639XMgul3","st_dist_05":"e20z9FafJ2o4Xlv7cL6PwNhf","st_dist_06":"mnJBfDTXlmtoFSgllODScS4Z","st_dist_07":"9jZBy5YhZdzPDiU6etVyFKyx","st_dist_08":"zt6fDpCUPEtyWzhGSuVp9lqv","st_dist_09":"Lt0cbDz1NAn0QQphxX6CoBba","st_dist_10":"vbOBeIP77kzvFscnBQ7tiDar","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Jtnrk2hTzJHFWStzCnBDWCCH7YOVGzxoQKPvAvNBzXo1kz7Pf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1029,"st_w_id":1,"st_quantity":37,"st_dist_01":"keZNHxAOLnme19em6JrLcpim","st_dist_02":"qHjEnX4SQhSQO3elfNDYAPMj","st_dist_03":"dyO68RjZbgyXdmn25vcjCbJt","st_dist_04":"ynalFjk3uc9CO0M6UcrxBDH4","st_dist_05":"UnH02NEjZRMgo3VCxn9thTrO","st_dist_06":"CMaQqbskKjkDE4r1D17zx8uK","st_dist_07":"Gojo8rbXzWoYge87l5iBbUYT","st_dist_08":"dzF6EUIe57fSWFnMyuLzkKw5","st_dist_09":"wyNJMILfhYN5mcTPMWY1Fb2j","st_dist_10":"YZQlBKv3LkB0qJ497OZhsOUo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"teh5YWozYfNstIcsbywhvqCtEeDAd0BVersXXk6ynUe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1030,"st_w_id":1,"st_quantity":100,"st_dist_01":"pbb3X50NNo0QUG1c8yo7cnaB","st_dist_02":"RCQcjWHOQ3bNNN8B4sIRiX0j","st_dist_03":"ehfDObgnuClNqwEMj9bInmoE","st_dist_04":"1j0veQskvmQ0mIatGi577R4A","st_dist_05":"3RuR4y9T2vZwk7tABquNy19g","st_dist_06":"XXclDgnOv65oWuLcSTRkxbkg","st_dist_07":"fry3xUq6vUi7vCCz1EWMuWc1","st_dist_08":"WBYCZmXKzpDPOFNtvP9cz68E","st_dist_09":"UtqmTAQrrHCQrWpKrqo2hKVu","st_dist_10":"AidrCeSSwzepdb0Ktw2gaS07","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8rfkob1fwa34Pct1sizUFznCNWxkWiRq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1031,"st_w_id":1,"st_quantity":66,"st_dist_01":"m3GUxGRy9B7lxc5ttpe3jSMX","st_dist_02":"KxBJ3sfjOOVYc0mueloYBanN","st_dist_03":"cnI3YdXHCA8210Aw2YufmitQ","st_dist_04":"9lGWd8qbmIIuS4hySbdFLx0b","st_dist_05":"8EZ6G1Pl9uLlF1NPuS9skDmL","st_dist_06":"EynmVJTrhW0tJcTPgRbfN6Ko","st_dist_07":"4uJv37exiV6b4y9SuKjLOC3g","st_dist_08":"yfcMfbZ65eNhzWSlv5AIW0oQ","st_dist_09":"jj9hi5Qo02aIT17Ome8R4vWD","st_dist_10":"m2631NPhtb2xKMmYnp2n11Ft","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"86cyEncrOzWbzzdq7sSA3DCRaHcPWECzq2EYCzpQJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1032,"st_w_id":1,"st_quantity":20,"st_dist_01":"Fsiry0sv1py3iqE7agHnWG1W","st_dist_02":"uXOQJ85GRLFpF1sKwbxV6RKk","st_dist_03":"OBlDzDT0yLukjhp9JzhrsQBu","st_dist_04":"uYmch8dnNc4zj09HOSfQopOY","st_dist_05":"aYzywrRLkAhPgLK8WG3NlkBF","st_dist_06":"PplATv0PQkXhOEEXyMrodiSs","st_dist_07":"siqB3WZffbRhnLmMVRjXbKSZ","st_dist_08":"SLEad3qj8bKXUfmDXth0IOVU","st_dist_09":"sndDnt4gmGZ8tiY2Gm8VHkK5","st_dist_10":"F8xnBgXa2wscuJ5vXxe8OfAk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IiywGQKrolPypmOKTRhoZsRCezMjdsk9uK01nvJbrQQfSmgnK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1033,"st_w_id":1,"st_quantity":54,"st_dist_01":"tICz7Eludj5yNZJgvBa9Zrhn","st_dist_02":"0rH8RCY504UHI8DU7eiyn6VL","st_dist_03":"j2552osdHTCCv7GsWHtV8SM5","st_dist_04":"M1F4u7YdwbaMMqvHWtq2C3Ds","st_dist_05":"mcMZMDgNsuno1KAZYufDWyrQ","st_dist_06":"uAyxq6N0GHuiDBN3r7UjjiHK","st_dist_07":"t7Z3l4VHp311t145tC6YhcpY","st_dist_08":"ZBcPQfBpeEFnH4gtL3PDggDv","st_dist_09":"IxmfjyUfNcXOBm3wpRrLVEsV","st_dist_10":"HU3FOtFAhshsWnLjpNLsfZ9k","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"u50AOVZhPTKOfkI5Xha9fzJmcuap"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1034,"st_w_id":1,"st_quantity":73,"st_dist_01":"UNNlYzfIf48th3I9PQjCSwTP","st_dist_02":"DdkC6KDL1KGxEgyVdMYRaEA2","st_dist_03":"nlIBhguiQxkMD0jZhY8ajfJi","st_dist_04":"RMJDDtqxMctRV49Gg19juUz5","st_dist_05":"y7tgq19DeoKBSsU75LnOXKMa","st_dist_06":"n70VRa1JmOL67CmZrX92cj38","st_dist_07":"SQUs42XQBMcEo7ISlStQeTjh","st_dist_08":"eX3Rx5L7M8gyCihbDwkqDmmj","st_dist_09":"dhQNcvxv5SCZ5Nzqw267tz3O","st_dist_10":"Mm5xChMMFAEj3OOuASenLwSw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hcMV7seLBrCU4SzXWyaHBrFNvz4hKfvB6kw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1035,"st_w_id":1,"st_quantity":63,"st_dist_01":"RiibZFjKmfrPZhtFQSXHR7Rc","st_dist_02":"57PzpJieudwyVXVVSc04Ox2k","st_dist_03":"ueIfR8wtY7B25GTynuBRV9ab","st_dist_04":"09pvKO6w2Itj5g0dGwmFWpQi","st_dist_05":"MQXauOCqKF31RVw9k63myYtU","st_dist_06":"Xvgh1llzFu8byxSyJby0bQdd","st_dist_07":"4g8uCcZvX956piUDWs65mHR4","st_dist_08":"0m26cduzaBteaQHt0Gcb7jwM","st_dist_09":"1MFMXPHAZLtcwstToeJfihMi","st_dist_10":"aiaCc1x97KrqbxzFjeVvCy3t","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zedehXhPzKyFZXnO65c3fd8h87TCviR3f1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1036,"st_w_id":1,"st_quantity":65,"st_dist_01":"iaaHDVoO3TiAm9Z5pI7koKFh","st_dist_02":"zjGAay4qsZSmbQLmsvvW7CBQ","st_dist_03":"UCbd91D7BkJe6yhYpvbnW8SQ","st_dist_04":"GnmIKCo7LGkC1rXFLrdGSqtw","st_dist_05":"itwAOpAaIEsEtoUwFaUcIp28","st_dist_06":"WHNlIpaSvp1kF7Mq0WoHj58J","st_dist_07":"hjUrnTWQpoxiJ5GC5HTqylCl","st_dist_08":"VXvDJD0M4UfBZEmJO6XYrL9r","st_dist_09":"s9vJ1jFKWX7yYgRwZf8HN8VA","st_dist_10":"JYBqn3Vhw1ciRMnxHd83a4Ne","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OpMOK4z3kxtgnPAFWtGUAN2NThlvkDX22wJiCxgYmy71AzI1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1037,"st_w_id":1,"st_quantity":28,"st_dist_01":"HQqmzGDoPilV6xU6L1elytIk","st_dist_02":"gwIBOeTP9KMZ6dO0EFHrHMsY","st_dist_03":"qju5pv7GbOYUqRp3kW0GXwIL","st_dist_04":"QZLLUYzeJdjDNsK2VcG7sLBe","st_dist_05":"bj2cWlvvmArzteRRKQ1GKY6P","st_dist_06":"qL3SD0P3u4wJmN0XXel4rMir","st_dist_07":"obYCS8Ii20QkkmA72iHT1xt6","st_dist_08":"TEtkT0tqJzc0ANyJSyQkB8sc","st_dist_09":"ZsRjj4KOv8fdWSq7tQFwGa22","st_dist_10":"QMdDybNmUNshynFfDjjyPAiM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6e1WbGkdjn7tq0FxlUV6MoeSXGa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1038,"st_w_id":1,"st_quantity":94,"st_dist_01":"GcTi7FBD8c5lu4nSXRPj99tU","st_dist_02":"KHK0lESqEixvsaPKQ73IWcZe","st_dist_03":"mT6gTTEwOoCnCp8idwH6YR4h","st_dist_04":"zsx3AxAmoJuP3ye3JzBd60iv","st_dist_05":"ZHPJHJdhdQPLsFbTnanlBkbP","st_dist_06":"MB7zHdBr2uka6CZBv9EqF5QN","st_dist_07":"9OSsJYxqQ4BUILvdwizfGtAN","st_dist_08":"fXMisNHmnkyVp4las1fo4dEl","st_dist_09":"iuHgad92kiZVwM9ayU0n85b4","st_dist_10":"GbaNTf3PfYOb60MeJekuD33B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AmI7E191oAfBITDKynkcwkjjbtNTyXN5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1039,"st_w_id":1,"st_quantity":76,"st_dist_01":"l6q8rzGGgWkz6lUEOZCYssSQ","st_dist_02":"UHEVFhrejCgvBajBIeyMlDZR","st_dist_03":"gJoa9ZKeEZSFExnvNU6ta02J","st_dist_04":"FZBi2E4822WD9E8UdRURzQOI","st_dist_05":"DWQ5BdPFo3fbcTGU98fsgMrH","st_dist_06":"z37up59CNsjrUhGFZxIroBnE","st_dist_07":"VRSb1Ai1GfKpIvvqf6ai2zBO","st_dist_08":"zXky54C5oQH7GGvjzzlZzOnp","st_dist_09":"nN3VA9Aa5xTFrsx00WIWstFH","st_dist_10":"qoKbtFEOuB2fLgbUrQqyfj4h","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yc2VxI1mB6XssuICocSQE8HON6ZxrFtSyX631NVakStUdzCd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1040,"st_w_id":1,"st_quantity":71,"st_dist_01":"DDvQpGHuWYXG6Bh2AXbkJslj","st_dist_02":"RAprvuJ739NTAazhE9hiipOC","st_dist_03":"R0yrKt8Qbo8FTqBhzrOlJWEV","st_dist_04":"0NfmEAvPXBDZw1F4gSCA9n9W","st_dist_05":"q4HZ2Xd0pLbw3Gu8LTxHr6DY","st_dist_06":"0afmfrgIPVk9s7subzHDpGn5","st_dist_07":"ZhtSA3qY7m33D13yKVGp41kd","st_dist_08":"BVLCrivVWHZLPaKxUWi4PNuM","st_dist_09":"SgpT8WzlpFOmbaHeh9SrbMif","st_dist_10":"aDyDpB52SwCdz4li7nlLajmJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EkmTz1p3buecqHLavsjmSuhTktncvHHejGwHHre58Puwrg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1041,"st_w_id":1,"st_quantity":87,"st_dist_01":"li2c33YJFSeTLPqRiQPSjQ9t","st_dist_02":"kaMJdpIBWylf2LNQYkxWmnEj","st_dist_03":"0BmSztaZ8UrOOVioWojNR71Y","st_dist_04":"jp3LQfqRlENmUPtMg1g5y17O","st_dist_05":"7acSUUNFOamFfpmEfoVEnL7h","st_dist_06":"ooXnnqvW7cSeKpywudt6qEWs","st_dist_07":"daTUvhtmqHlaK2rva0BK2fhF","st_dist_08":"euLfVCIq6Hg9IHym0DGqz98K","st_dist_09":"o72tGjYn1yIOwbwwhNaojNtB","st_dist_10":"XafNhbVq1dxcHkS26tOreTNa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ziW4bKrr4Pd8znisVap1k4Hkb56ApNz3oNd0Z3OZJAnNpB3gr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1042,"st_w_id":1,"st_quantity":34,"st_dist_01":"90Vt3KtzTfv0bK3L7GsYqLHU","st_dist_02":"bRhS8M3zGPZGmXmOL6MsLa9R","st_dist_03":"0278XuPlRzkvs9NtLAMEzI6F","st_dist_04":"OlKWLCnyGvEfTVu66XUe41zu","st_dist_05":"h5jCl99mucrxne2KR9SuPaj4","st_dist_06":"7ZuaxymPHRo4dW2lqGEvdnor","st_dist_07":"XGrEJMr8JAVsitv1WI9e3Yy5","st_dist_08":"z9kzABhoB254NXClnRkCGn4C","st_dist_09":"oUu2aXRvTzVwsnAWDlmFlsEa","st_dist_10":"vAVlliiDCEklce8njVvzY5K4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fQ1fW4czC8aTPd5lM9GjRy6urxHFx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1043,"st_w_id":1,"st_quantity":94,"st_dist_01":"IGdeHmatVh2SGstFLoPMxf8C","st_dist_02":"Y1f8Vk7G7AnRYJTq7B3JJWuJ","st_dist_03":"gIaba4Ntq7Z5kOv0527Am6W7","st_dist_04":"tCxa2Q2nT4hNaa2do4ihDULG","st_dist_05":"dGPdqbL9SiFtaroWxPMvwyhm","st_dist_06":"rippb7QzJ7k3ctIMsLhwIOXp","st_dist_07":"u6DBRRtio3C06WGK3A4XtLVv","st_dist_08":"f4hYxsIad5lVF3M9e21Aptsk","st_dist_09":"FUXn8gLTWKCFg8CTXXLZs4Q2","st_dist_10":"6DO1K2VBjfHPVoYtFOpXtiEy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"H2KGzTb2m0GeBMuOkzpy2NrOHcn7u8Fjb03KZlKkjdZIHoNah"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1044,"st_w_id":1,"st_quantity":94,"st_dist_01":"6o8TbwMkraaTB3cl0O0wlNfF","st_dist_02":"zfEhVDDbVUj27yiu84FFaEcY","st_dist_03":"hJnIWgAEzlPM7LSaTA63gs2F","st_dist_04":"uNI3EYLDNUvsKlGwWSyvOMIO","st_dist_05":"8c1M2UuPqQ3V0BCYfSy3UDTY","st_dist_06":"BZVpEOaVsXWv2avJ6Ta0P0xg","st_dist_07":"m0khxQbiuvo7u3fF9mRKiHCh","st_dist_08":"Ps8ZdAp5lKhUKwAUtO3O1uhb","st_dist_09":"86bjdCC4H5EigXSCdbyFjIoT","st_dist_10":"rO6VLiA0KR3RIiyhA7ty1wKK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IiECEkj4frIYP1ZJHzq17VQeCcb6sECszF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1045,"st_w_id":1,"st_quantity":86,"st_dist_01":"5RkyuwlZUyJ4XP8J9sYQt2FW","st_dist_02":"UJ9dd7gvD2FUS8VqlqRH7tke","st_dist_03":"rwmeMnoF7aBvS9c1KsJIUvWT","st_dist_04":"cYvdYjbNoYXrK6Lmfmf5EHmV","st_dist_05":"jIT0FrlObA7Npq4Li2677o5s","st_dist_06":"j5442vELjpEkoqKuoOmbqisN","st_dist_07":"Wate28OOKIe4bQ7AsrG2bzmh","st_dist_08":"PEzEd3slvzbH90hP5RRd0d6S","st_dist_09":"oEn5gr954s2TmNTTQRTaYHit","st_dist_10":"5iYywz0vDNYPkcbaVZkHBMY2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wBworiginalniJts53eYgCXxWXyGP3sm0O"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1046,"st_w_id":1,"st_quantity":23,"st_dist_01":"1xJGKwNBJW1nkgILw4kqcuWY","st_dist_02":"AFc7sv0A9HXT0ngRhXjWcsPD","st_dist_03":"xrZZH367Bl9Y3yIuMe8WCTIw","st_dist_04":"HNrvAEaBT6yAVIGdvOW5RWXM","st_dist_05":"ybru5cc4YsAR9vQwAEIZ8nWW","st_dist_06":"R6WRdblXKxFsY4S1boM1C1fL","st_dist_07":"5uU8k18Np3l0EhMwTosHArdz","st_dist_08":"QzUdqdIgHIdvQhQqvxSfiNiy","st_dist_09":"2kpBUjAKzbEALpgJGRl9SkZ2","st_dist_10":"orPy6jxfMJcfjBLIeUNGPOQ8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ux0OA7Sc874fqVDfTAn7fqEsVdkVeeFc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1047,"st_w_id":1,"st_quantity":78,"st_dist_01":"xcQJAWkt96Lrgmlz4aJytyr5","st_dist_02":"qRRa4KzDQcjPPJrhDteKX3hp","st_dist_03":"Hcvs1FrIJbnKDQKvAyCi0lPy","st_dist_04":"vTXTy3XGKwAeyMZb2RUp2Kot","st_dist_05":"ANLnYYvMYb4RnkArZJt2lV4E","st_dist_06":"WWQzqSevY8ELnqpF0hQA7D9l","st_dist_07":"MWkEx5hB6t90eCCeBQpRly4d","st_dist_08":"L6xpfKotBGz9uZqwoI1mo5Np","st_dist_09":"SAyhoSRMBwrWXVfWGBYc8LDt","st_dist_10":"nIkkjHrHOZJmOm1QFBe0FsIy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8q3bKlQe1M1Cqivci0jNgpisldkPcRybcIApIiwqsNnjwp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1048,"st_w_id":1,"st_quantity":61,"st_dist_01":"DB7X1bLsrDsjXlStLFS63hBM","st_dist_02":"VktYbLJjeWQMrPG0Uw7uKBw9","st_dist_03":"svRndWbulys8XkfjyzOA8KVJ","st_dist_04":"7eCEezcQeAcAihsWEZlCRbeV","st_dist_05":"pmN3kiEbgy8RWtvahgMIMmq6","st_dist_06":"nYPcvkuKUUTSmMVjZLfGCqNz","st_dist_07":"sE4LUlbGPL77AdjEasaM18BD","st_dist_08":"cLbog2zWHYdTqw3cpEHgldAH","st_dist_09":"CwEd7YWQalyqQBYPnFWYcDME","st_dist_10":"lE3s76CYKKQ0ccoqEEqpJgr2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QZPCzE9GboEAUxRbBa4jxYxCzWCPvaP9ocT1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1049,"st_w_id":1,"st_quantity":37,"st_dist_01":"wQCmYV0zyzQG17VGJJJzBu5h","st_dist_02":"qjZFKrDswImBQdGGaM5CGuHr","st_dist_03":"mRJ9CbCWJpqmABUbEiMfxI76","st_dist_04":"wIms7rniFRWJot0eHgO9KWJT","st_dist_05":"IuouD5I0eZ5w3uL1UImBPCUG","st_dist_06":"5DqhwOsLXfCnIjwC3IAHwndh","st_dist_07":"gQKN28b704G3jlSTXVXmhsrb","st_dist_08":"hMbegcb6sID0BRIXTfCCa5hw","st_dist_09":"r6XcHakHLCIYQjjYhPSrAtNs","st_dist_10":"xyyxSlQQFhWJroAWhCCRYcVV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3P4cjtzNCe8beBmrakoLewSohL7WY1I1UqVb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1050,"st_w_id":1,"st_quantity":51,"st_dist_01":"uKklzrZBAAAa4uqAPN59Lzgy","st_dist_02":"65qOwMBmY5xwEGPaex2VuVaW","st_dist_03":"o7AdnEapT2aSa3Do5sT3k1zW","st_dist_04":"ltNtKNb3HDh2LbLLvXdNwosy","st_dist_05":"Poup7q4w2pjuBOA4XJwXmMS4","st_dist_06":"BL03FM6Uny910UsRBLsXMV4Z","st_dist_07":"jRuqhAG0dtyANWqDeY8jlNNF","st_dist_08":"N7rk2kIMsEtLnBXs4UXl9a6q","st_dist_09":"3C3D7rYy0lcxohsV8MHPBqUb","st_dist_10":"LOw2b8NrN7zclNfs5n0eOZlH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VF3YnznnS6BsHFN222a5lC38XCRKR24wuiqc64iE86Ede2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1051,"st_w_id":1,"st_quantity":97,"st_dist_01":"9JqvLAOjfXz0bx1yBsFv4lv1","st_dist_02":"Vdfsv9rGMRdWvZzEHPrcHHf9","st_dist_03":"UfosPAzdWh4irA26WSqDTvf4","st_dist_04":"AgcjxROGLTTocx9nPGF87F3b","st_dist_05":"AvGyESXFSDxzJ2seDp0AXTPq","st_dist_06":"wYeqdbQLaqQ7mRkNqHzvqCDI","st_dist_07":"Uob4iBZzyXb5UUK25Q2XTVkb","st_dist_08":"TVp1fkfBkNSixOhqH1qwRvFG","st_dist_09":"5enaNteiARkZsTGz5fBgObok","st_dist_10":"3BZccyNCkYXto3yGUSblXlh4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cyKE5Jvhke9wjRm7U3cP3j8KlUJ3yP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1052,"st_w_id":1,"st_quantity":78,"st_dist_01":"Voc8q5oG84taVstQ0R1GfgUh","st_dist_02":"fN2myhXjvJrAyRCpp4bOY6jw","st_dist_03":"P3FWQfC6q323RlHCcBnXnM6k","st_dist_04":"tnotyC02JTutPo6mjX0WWwhj","st_dist_05":"RTgApBuC9hfRSw8YAU4cQCMK","st_dist_06":"AA7RA66jHvrNWoN5CrgaXY1I","st_dist_07":"sHMzFBEPngm7wfu6tAfChXMP","st_dist_08":"lVwZoxfJJ5sACZwznP51Tfpn","st_dist_09":"zK0C6LEmVwPqcK34ikzNjsON","st_dist_10":"9sA7Su4wqhMPmmSy8nWnynN6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fNveuCUCcvYkZqiMXJ1kRwuzhlv68XO8or4dLJwQ22A"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1053,"st_w_id":1,"st_quantity":68,"st_dist_01":"rKScWYGe5Ag3bnUKiHATzcTF","st_dist_02":"DgcuQhT9OKLINbsHQMblPRj7","st_dist_03":"eD5Dr0ZHQLOMekAYQpgBnxHA","st_dist_04":"oOt8smsx07bbxvhdf8D7AIxp","st_dist_05":"mVORjnCan4nBApFxCzkoYsVg","st_dist_06":"BnXTfvClDn9J4fVCE2kZfre2","st_dist_07":"jVN0iUjl7udK8U2ZDGT0mlnQ","st_dist_08":"N8URmtLfBpv2N6K8R75YnCsu","st_dist_09":"nGYnpDnS2BWSJeLMnupncOld","st_dist_10":"eldLZBY7ljThM80492oPEFXU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kbVHOEX3kWydUL0kUshWQA72ymbeyJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1054,"st_w_id":1,"st_quantity":73,"st_dist_01":"8PmZKo0pG2NpDS8MfwV6NO6Z","st_dist_02":"w09T6mjVJeoq1i5XJk8Q2nKc","st_dist_03":"XZLiIEnlv745FuLIVAvWSumf","st_dist_04":"hpeV9BLqLnWRW09LbwSmqPf7","st_dist_05":"HBAQawJDyRENd1HAhmt3T9st","st_dist_06":"OPpzWwHImCIH8mGyYDFvwoCi","st_dist_07":"AAtoHc3ngMWrSPJ0htI5uidV","st_dist_08":"twUPVzS8YQWaGtcZwX0rAKTf","st_dist_09":"TfswibqbwPCFvz9TVMRZFvaR","st_dist_10":"4q6BJ8Qje0OrRbPM8ya5Yl5L","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O1uixjNTLr4JHX3GF5gaoNBxXu9FAThtL6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1055,"st_w_id":1,"st_quantity":45,"st_dist_01":"e791899IlO5YeEIule9lknD8","st_dist_02":"n3qNwEPIzzqljnyBvDFJpgz5","st_dist_03":"Lpq4bPppJ91GhxQkgZZog9Pp","st_dist_04":"EvDkeAuyUBHYcTzzylok21yE","st_dist_05":"nWAYHb2iR7y673nW4wW1SpMY","st_dist_06":"DyOa5tYw4iQkCrA7K3oeFgjl","st_dist_07":"MVxEBvKF4F5ID91MrRaGLTxP","st_dist_08":"jDkgoR87p9ZjsetnBpHUYw8F","st_dist_09":"0vLntNpJFDv2ZyEuJc3zexdB","st_dist_10":"PFMFBnoEZensLZ4hZQyOIoHs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TKNKuVsJOGd0YdlfMf8J2JzG1xwPww1iIvscwBPSOr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1056,"st_w_id":1,"st_quantity":19,"st_dist_01":"8XasFzRPiqw2MCU0hreisVHb","st_dist_02":"M6QwyD6EiKi65n9OpdTUVbGi","st_dist_03":"bjKYJFXuejTkdd39cx9I0Wll","st_dist_04":"bzIT1kqqcquZY6c5X7xqSxNb","st_dist_05":"vrQj7MqnVq36BRB6fImEE6s5","st_dist_06":"EVoIAyk7N5X4QZtl37Cpgq5v","st_dist_07":"OdbtFpZVHsVERRh6LpUD4158","st_dist_08":"HvTG6FCdKJ0fh24AjUzPKhzW","st_dist_09":"qKNv5rSEHIhxbkhMy9JRLgwv","st_dist_10":"rG8fkvNBa4VlhVpj6uQIzLhC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uoT8JxkhyBODQS0Cq55EzZeDOL0l3W77pX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1057,"st_w_id":1,"st_quantity":76,"st_dist_01":"34l8fHG58XIeTcLwFKOD7OWt","st_dist_02":"umNGQG8caIQhOqJFZMkFbHS5","st_dist_03":"uGG3K3F72ImZnzKu2yV3ROqr","st_dist_04":"1yEVnPs6p38sjl2vnOTjArpe","st_dist_05":"gxQMSuBW2GUUF74sEPpfBJC8","st_dist_06":"qcXageNEPiEp6SSsydhIU4XF","st_dist_07":"WDixqV8GZ90UpZxpCifS5bZa","st_dist_08":"cuG749zijm0DDqM8oEmpEBVX","st_dist_09":"obGIAIEbobLYLwuIR04oGs5n","st_dist_10":"5HEB11iJtCQVoa7obxlSWjNz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ELrwapwxhoriginalDpkJPtNpNl103N3iXg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1058,"st_w_id":1,"st_quantity":75,"st_dist_01":"F0o8J4uh4S8yEbnrOxnc1OKB","st_dist_02":"fc1FyhTZQvUcdBMopk80qDqN","st_dist_03":"dKgmbeF6BwimTKZAIGuCO9U3","st_dist_04":"OFOS8I9q5iASOBoHHvjNo3bI","st_dist_05":"sAMLcUCZi48QBsVGilth7hnM","st_dist_06":"7zB1YiZ0pGiN9hWTviKOy7sX","st_dist_07":"6VtUUy1drgqYg4T59BewjsN4","st_dist_08":"8K4EBfX05i8hHCpPmv6r1JL3","st_dist_09":"GxI4hrpnJ5E4nGueyoBAo3Eb","st_dist_10":"woXWuprIVrOvwhMhtOINIEpR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WWCugiTxwMcOdnRF2CBeN9Ou3840gXb3OmWG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1059,"st_w_id":1,"st_quantity":72,"st_dist_01":"U1LLuCKRu5eRsjqcfWpo20Km","st_dist_02":"KGhOxzD05rR1YP8WP591CKk4","st_dist_03":"I4AyZwnUmHjrUiK6cHir9odw","st_dist_04":"aKQSiYc2fIPkCZKTp2ZAZgCo","st_dist_05":"QLWYaR3WFeUdf7fkpBKW1Pr1","st_dist_06":"EIwqCQybWjcTQqo62G4UAT99","st_dist_07":"yH4CLZYoz2XuqnSAPFbV4pNo","st_dist_08":"lhBCTZHvuiD6lEhTAO266lBg","st_dist_09":"0ACatj6bwKYxZMoSAAi2daDl","st_dist_10":"kpjYMB9o5EUOPWAZZCOJvCmQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qLAhWSg8oE3Xn00tt4gGwJniFG7C4Qcuo0LR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1060,"st_w_id":1,"st_quantity":96,"st_dist_01":"3XTssPfLLIRFqopA09TMLSSe","st_dist_02":"X4XdztvJC6kI9xwP8jYHC4cf","st_dist_03":"a77hHXeENGKJVaHsURB5y38n","st_dist_04":"kWnBQKBuPZQkFqZcLQK1YfdA","st_dist_05":"1XYRF5BT44ilbDz9X7D5QndN","st_dist_06":"QxDDAkbNDYHxgJ2ZBMwka7am","st_dist_07":"rwvvYKTY2rECdLftreMJU1XJ","st_dist_08":"YJr1bvGmn1oBaEFwafyPVVp5","st_dist_09":"JAljm1IEQltfuma0m9qUOjYC","st_dist_10":"6CQG1ZHWgpFQDKYyU9Yxw4Mb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sRQvzeFD08lvQ2Sb7MYPIEFTXYB58ahw0im"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1061,"st_w_id":1,"st_quantity":100,"st_dist_01":"le1vkUp18aYmUgr9hnPluAQT","st_dist_02":"jqfdYjZJY7Ji5B2LIzJd2Zur","st_dist_03":"Sf9clO0wmK4CVTLcPCfo1ER1","st_dist_04":"kMvUHlIbT1RG1IEAJNorD6Pf","st_dist_05":"66aVjr06e2dUdiz7WVpeCtdr","st_dist_06":"zBrS0JW7f824z4TfrTS0XIX7","st_dist_07":"In8P3sBjBakgND6WAObmmGVW","st_dist_08":"N2fMl2bmf5mkEIPa7v2M4gAc","st_dist_09":"SnHhur5jyVEZiPoogeEezHOa","st_dist_10":"ucb3LaLi3QPqGT1LLDiEtzxb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"megk1I8SLAe5XrtOw1j803tBHvZ4PKWOuQXtof23Q5xlll42Q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1062,"st_w_id":1,"st_quantity":72,"st_dist_01":"ep7nNkryVBBpKV9Z4j4Ql8YT","st_dist_02":"hriylwh9MA27TAwRZE6nqXnD","st_dist_03":"nougTl73TAcoPWVqYpQDYt7i","st_dist_04":"vBt6xipI3gKKveREw3tohX0Z","st_dist_05":"4a1FqqlUMOJl7vhGGXPoSD6Z","st_dist_06":"JwSIV7EHVXDs5rsrtyf0OwjT","st_dist_07":"CMYGxUwQ4LxvIcyrM1i7C07C","st_dist_08":"gFbKVrqHESvO85e0TQw1rqyd","st_dist_09":"4m0LFP37DIaPPoQlbzDGrJFp","st_dist_10":"yBpuGSHm4yq2X1qw8o9aAJgp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fYckfFOmlasVIrRnYDbMWENiy2QMO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1063,"st_w_id":1,"st_quantity":28,"st_dist_01":"2MZPkL0E546p3Cv3z2htSkiF","st_dist_02":"JUJTqRAQNASz51FwdCcCcbJu","st_dist_03":"iBerXwy6TvISRNsjLqETHDjl","st_dist_04":"JqFsmNvhGMQ6xamVEAEn4XS5","st_dist_05":"W95NaZCxPXKaPELnCkMekv16","st_dist_06":"bSTfMccXFusqOegTpsCSQMsI","st_dist_07":"oyKzE69ajO25GwxJjz4rjs7M","st_dist_08":"6VDITG27GsitNncEcM95WB2P","st_dist_09":"0g2Xggg6ejuz0GPfr0Fhqe8u","st_dist_10":"3Cuh3QCm8fJnlhZbZfPDQHFB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wLKy2QPzR6VhOOEmTT4zUuzM1ifbMDhZP6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739243,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1064,"st_w_id":1,"st_quantity":46,"st_dist_01":"vScHojevCBGCCLuVrpvk5Eh5","st_dist_02":"ec54V9JvCWu1mDfLCz1K22Uk","st_dist_03":"zNPWGODXYhsHE8mlqbkeogc4","st_dist_04":"DlgS8U749f9Za6MQfc3wEyXB","st_dist_05":"K2U6wgqN3fz3lJ2143eGd6gR","st_dist_06":"1ShBHcXjWZIN8vhHbVOSSVxe","st_dist_07":"MSbdg8Bc05gXWAWQsWMJFWtI","st_dist_08":"KP6Dj1fu8NNGxCgmPsSyCdtb","st_dist_09":"tDM33kWyvTq0YyEGgnPIqotB","st_dist_10":"3jSBdkAe1FuGffs8icN90EaU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EtY6STfsENNucxZl74NF0HDB1lsax7MMIbBlP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739243,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1065,"st_w_id":1,"st_quantity":76,"st_dist_01":"3HRexPo8I89yXtlGw9co08BH","st_dist_02":"jwvWroWuJQqEA1eHPBInJ5DI","st_dist_03":"E6opgWlJRq0ONoSXMjkWz119","st_dist_04":"VzaeOkPjw4gQivfmz71r3Mbk","st_dist_05":"vjgo1ZSUnriRtKbQknO5hqyP","st_dist_06":"v1iuHpnbXZptWY0jE6CnTktd","st_dist_07":"kR5AVL9Z68R8vWMlaioddobD","st_dist_08":"FTdcIaheqX9tFro9Zi2eXd5g","st_dist_09":"FQLICGayWsiSfIfwXgR25P3i","st_dist_10":"F59rVXyug0f1Bi2NAfQYmWpR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"acNUyLuxTXeGta5kBW0pzivCKMpd9lhilp4HLROXNeay7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1066,"st_w_id":1,"st_quantity":68,"st_dist_01":"9vEKUNy2nK3beWrzaEkY3XMV","st_dist_02":"Z9ZcBJ40FiQgbjig9n3gDWVB","st_dist_03":"MqUlc7qsZD3df8UsJSNbqsUG","st_dist_04":"CA6BbdtYVNGxHymLEaEQTMWz","st_dist_05":"YHH9WFlkpOdVIBtE5zexxNZk","st_dist_06":"LvCMkdSveCfnWdW4Z3C2YK9u","st_dist_07":"cc7Z8NJxxnhINJ607SzvdnuU","st_dist_08":"CEL7gCYMfV64d4MWfbDQFBr9","st_dist_09":"yFOMPcVIhakOiGhWkLZ5UiyI","st_dist_10":"rx5HWtLUELTs0IjftzBFjKlb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"n8XdOxyTTXE7ciJeiNCCzPMqMPzC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1067,"st_w_id":1,"st_quantity":48,"st_dist_01":"o1L2QVS0dB9GznmXhb46VIRC","st_dist_02":"5vsOZPrI61iZ6xazv5d8S50u","st_dist_03":"qRNOHJosebaxMC2Jjs7ZfVq0","st_dist_04":"DQ3LZ94zUQA3oRUMuvxQuSWd","st_dist_05":"Uu9N2fTm9zKEYhpKlseH4lDv","st_dist_06":"NCIwLMI9LUhx1zxENfo0r8hY","st_dist_07":"lE2h3Lmag5eu4bS5JrvDpkiP","st_dist_08":"9G3hthdUjLvxvL9kGDg5xBGc","st_dist_09":"SourbUTScCbM1VwC9JVzMHER","st_dist_10":"qGo6O9esOpY0uUkShUNmLWdP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O2m43Hy0Vgc8qbDKgyq5o57tbe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1068,"st_w_id":1,"st_quantity":73,"st_dist_01":"jnyIDLSqHSsuakyq3jPiNkpW","st_dist_02":"23DzFlALmE81Ia89fv9yrKZ3","st_dist_03":"BJ3vxV9WqRNXS01Qw9802BlW","st_dist_04":"PFOtYgEu9YbGwywREo7nxJGn","st_dist_05":"DDI1G7Jx1RmHAbP79PtEVQOT","st_dist_06":"VNvT9ncmdqAeRrXcN2KZHb4s","st_dist_07":"d5DebelaXbYmzSr2DUSA3TDr","st_dist_08":"n2Ku4EwoeK5wP2CrN9AHVj1D","st_dist_09":"2PDBPmKZKDFSDNAVY1iasnEV","st_dist_10":"uU68HYzxaZ3CbsmiRYZM7NCe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9wdU3JXWdtXWsejUQ2gBOCCgEX1jFnw5HJ4V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1069,"st_w_id":1,"st_quantity":65,"st_dist_01":"VSsBZjGZvOHYSyKPscitL1GK","st_dist_02":"KmJJR74YmHu7yG4jkIS0LjMu","st_dist_03":"PcfBrfR7bCiuBytdnFR059Js","st_dist_04":"bSVsYoa7IHgPPeQUJOMcwhdw","st_dist_05":"1a8AndtbeizT22DMT3jUjlHw","st_dist_06":"OvPwoHiRzmG0jZFhXAfIW9ez","st_dist_07":"agLrn4oGlVyBD99TIhzW643w","st_dist_08":"EnnIMMSt9sbRHvXI9tWrRZe0","st_dist_09":"LM0Uzql9ZSYdPRc5Jf9H78nY","st_dist_10":"OrsaGW1JrRL2racYVfXqz4fK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DtYTBTsj2zoiG9UWmlPEEr459a8AyI7EDIKn34Gy3kcyztO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1070,"st_w_id":1,"st_quantity":48,"st_dist_01":"IEVzPILijjPLkErjb1gMkXvD","st_dist_02":"UgrfOxllDailMMzGU54R4Ms3","st_dist_03":"57fuWLN5ReIt2Zu7UdyvhXnb","st_dist_04":"mFRizxVsQMNbnM7GgZVnNu0Z","st_dist_05":"giE4C7c7yLFS4lqp2imYyHkL","st_dist_06":"zzmwJP0TXW3zz2vpK1ZLmbn3","st_dist_07":"xxGtkkmapxwvhHyZo2TmPUsg","st_dist_08":"8lhRbopSwnaKygHZPZckA7h1","st_dist_09":"MXheEfJAXnCULzNik4AogL7U","st_dist_10":"yPADItcUMcBOllMm6LyIB7eh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HQxRiQKXDUONkpn2c3z2c5u1F8bwnixP0JWlEE6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1071,"st_w_id":1,"st_quantity":64,"st_dist_01":"nEGLy7RUzLkt08A99KA8Gd2v","st_dist_02":"j3HA1pvDHHZ1qqUkGNs6nrAB","st_dist_03":"U1wzU22lO6vtHP5c46cqJQIs","st_dist_04":"L12NUNl3Lt3z6XM5MvATphZZ","st_dist_05":"xF24qDJRSa7oF6ZEoy50M6KU","st_dist_06":"Wd49g8QBy2tsV1fceNTH3JbQ","st_dist_07":"ijvXAvHS5mB1HBvzHTuqcY1n","st_dist_08":"nX5OPJAxvSnlopF83CGSLsvu","st_dist_09":"OLIE0eKHBU3jQI7rDBz3yMlG","st_dist_10":"LVna8yrb0oiDLX4GYynTqJ3x","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"A824XVrdAocz1UB7kKrIAlnHm1whxsyRfPwvds0jJwWMg9TO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1072,"st_w_id":1,"st_quantity":60,"st_dist_01":"JDMOerVHVXZRYTWNeXyH9eCb","st_dist_02":"Vlszvdhd95eczktQnb5tzUlO","st_dist_03":"B0H2UWNIb8G3iutCAyfAMVsw","st_dist_04":"CEtMJf2N97SrODz72AVTqKRW","st_dist_05":"QdFQbGKLNx5HmpAWOeoDOhkf","st_dist_06":"gaR0dmLzkpgnsGezHtJ8WcAh","st_dist_07":"A5rJAUU2z9ZbGSQUto6dFjPE","st_dist_08":"nJUAzyTkqoUqhCxBmWEVG6Xf","st_dist_09":"c4BLQrqWJZZMrilkn5La2TmK","st_dist_10":"AauSl34t4XBVqgjsw0Wq1mlN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0Mzm5GrNqnUWjSrsd6EwCXvd8e0LVdcc1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1073,"st_w_id":1,"st_quantity":38,"st_dist_01":"dNdZh7UfshqyR0Aqqg16udDy","st_dist_02":"4PhC8uMqaw0F7T9DuEKLThim","st_dist_03":"GuKwLPa1oilkVrKeMm6NSsy0","st_dist_04":"7Fa4Z22DHJHVNhzfveF2QlpE","st_dist_05":"UWZj6BMhfLnZ8UYCf7WBOzyK","st_dist_06":"9zyniXPqcXsJek1Zu61kzGXC","st_dist_07":"1vAdPpqhHQJch15PnTS7gcCK","st_dist_08":"8CbFImRoEa5uA0tyXFBKSsiF","st_dist_09":"dJtXnS2Hlkli26hojJ7PO38t","st_dist_10":"cS2PtrhvCPZECPOgjGxaF0lT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Nze2NX0N1EOf6BbAm8LJOOAMmuCy8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1074,"st_w_id":1,"st_quantity":68,"st_dist_01":"Nf1S5SMvrV3pv4bS9xR0cTeE","st_dist_02":"n187KfCia5x4SzbnXiF1EbRf","st_dist_03":"gVdz1DKs01R2iFKf8rx3BppB","st_dist_04":"105VYi840g855gOr1SbxMvdN","st_dist_05":"KL6JenPqDT9cThiHZCRC9VGV","st_dist_06":"av4d0EU5NTKwSP8J57pPVbdq","st_dist_07":"Ai2nwCIPwQJfbjYpoHrdX31O","st_dist_08":"2CLKH19snPoExISgpcMGBRLn","st_dist_09":"2M3VeVANkg9ZMbZpDca1xxNf","st_dist_10":"1RnH1DpbYaLfNzgR4Kbgg69F","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t9oNITKU3fjoriginalab0lIssS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1075,"st_w_id":1,"st_quantity":22,"st_dist_01":"Tt8OSd2evDOwxHKU5UA9cFOM","st_dist_02":"Dn4LXXzuyt8EyugEytwZURGy","st_dist_03":"S2XTcBupPoY4S3cAWT3GZeZh","st_dist_04":"VygytZ7hCYvAKoOaOLKn4wyj","st_dist_05":"N5U7Cz3uIDjT4RpPh40Y3Tam","st_dist_06":"MT5hfNSFftDAdNHFOPk5Qg0K","st_dist_07":"oFjUhlNO3DoJufauZdbVskmr","st_dist_08":"ZfHvtJQhMKFuQrneHAuUJpXi","st_dist_09":"QM7OhetSrmeCWOGkQuQHRnQy","st_dist_10":"UPVkiQ85Q9ftafiP2eSPRuS6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aDFa3Yc0tzrZekOmbeIcTO9hYUqJP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1076,"st_w_id":1,"st_quantity":73,"st_dist_01":"oYeq5UnwUt7OBbEzosSFHdHB","st_dist_02":"v7d5nAi8jMvtUraRqVxobgug","st_dist_03":"CE8IV1OHPRMKJzhduMcVEhLX","st_dist_04":"sKLKOeDgkElqz0AIbbExVLYF","st_dist_05":"EMg5D7gxAkLJqStq3ESZieIJ","st_dist_06":"kGms3a9XPFTl5zMPOCXTXv8B","st_dist_07":"IO4kKK6vD5grWeFr0wjfzcpt","st_dist_08":"Hw8iYj8TXVG2BI1PNL1nffcQ","st_dist_09":"4dS5kNQlr97wtTosOiHscMov","st_dist_10":"oWjSSm7zinAWQuxCVTp0k6j6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"G0w9AGKYc1CIMWwUvlJkgHWkCMKBPJZRb6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1077,"st_w_id":1,"st_quantity":48,"st_dist_01":"CZfmAm0480KEhtgf2M7rC5WI","st_dist_02":"aseXf2z5iyZktf2GQIPqSkVU","st_dist_03":"QKfm5BDWIYDVKUmTTkh4DX5t","st_dist_04":"HYNDSmbGoEahSC8Sth0jujIV","st_dist_05":"6ywMkI3FhhMUjfYwc3I10QjA","st_dist_06":"V0s572oiWN9xdXYFCHIqcPzI","st_dist_07":"VjRwezQm73AFXBNUZqmgEfAI","st_dist_08":"2G8K0hPMxBitj3DVKwAqR7Sa","st_dist_09":"0P6q7sOqX3zlc7XaqA6Lbvdu","st_dist_10":"72yasL84U50ZB6wItsn0Muto","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kSPdWsCcB2FjpYkuz3vMzNWlbu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1078,"st_w_id":1,"st_quantity":36,"st_dist_01":"HnQ7qU4jBm5n60RkZmCik3iX","st_dist_02":"QNPLss1p2Gd987C3mha9De66","st_dist_03":"vcJcOM0rPjcrB5BS4VTfVJcb","st_dist_04":"1Vw8unP84iF0ChQSDgZUaWZ1","st_dist_05":"XCv0OmLhWI6Ayy5GMCGaXAoz","st_dist_06":"yf3YNL3i1wouyKwf4eroC17R","st_dist_07":"kZFzh4d4w2HbOGUPagfvEyPp","st_dist_08":"BmXOtrfLqk40kUWB4Jj3cupJ","st_dist_09":"ICgVowu8QuC8YVBukMYEK1Bn","st_dist_10":"TuQhtOojozVOnaStQdQeybd6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MUfI1u0ONQj39occVsahDY0yTfjhRj2bfZWXNzk0C0nca6P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1079,"st_w_id":1,"st_quantity":13,"st_dist_01":"gz0mS8nByi2WVa3mmI1Abq46","st_dist_02":"f1DqKGU9gVALFCn2556EkmVf","st_dist_03":"QAlH4m8mFO57n0AKGuMxdrOQ","st_dist_04":"i1h8S9bDBoBgdMrhvYgQv5Xb","st_dist_05":"GdNtviYWLbQXieF1eDpEWMyB","st_dist_06":"OB5iPI0RmqtWjAkJuEMerGq1","st_dist_07":"P0eOqXwiLFPj7rUbaW8Ma4e2","st_dist_08":"3XtoFJ7EovNToLDDBjcrZOyV","st_dist_09":"xIWTWsXdCvycgZgLPcBYjTwC","st_dist_10":"NTaFYojtbGx9TLvzK61S51Cl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xBIj3xxYK5kB4eK64DInQwyVepCD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1080,"st_w_id":1,"st_quantity":16,"st_dist_01":"n9cj2wRluL9JjocshjKEab1Q","st_dist_02":"3HAq1sTjx7QXeOLUyuUONs7a","st_dist_03":"TliZZKTOfdd1cg7mecFElZmV","st_dist_04":"5IBLOfLOihMy6Os8THIPncay","st_dist_05":"LyCvGG2gRsk22YHlbCZDB0T3","st_dist_06":"zvpIV2iawnpvtuDXQYawULnB","st_dist_07":"kWTt8GwmHPTIPdYspbXYNB37","st_dist_08":"BrsflyNEx1WSzkGOFZlxArRw","st_dist_09":"ccuxjyR9iRvRBAIEUDkD4xnn","st_dist_10":"WfWbZmmLpmfNI6GAXDNAcPj6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AbPkfKg2xbsG3zodajlD8ur3ig5KIUvw2qHMJMsYOskeQ6xFh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1081,"st_w_id":1,"st_quantity":63,"st_dist_01":"jFwpQ0IE4BFjbX9g0MUcXnbN","st_dist_02":"fJJHDxuz0Qg1ceF9uM3P6i7D","st_dist_03":"ZjsOWvPqLHH1VhhbdfWREHu6","st_dist_04":"1n88DpcBbRcywu9kumPVMeJJ","st_dist_05":"WMHOcMrnQgjjwGY6dtBr4548","st_dist_06":"O1nHbk2oWlWT4MckVIz8avvz","st_dist_07":"9cZMKLDbNs3O6jbZ4riA2Wj4","st_dist_08":"QcUsqbQSizKwxc0UJtAMZIQp","st_dist_09":"WDBwsmccGfnKiXl2I1DlI5tm","st_dist_10":"XgfzyeUzUdLheAyv1qY76cq8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xUJ59a9b4RWxowcg0UUBoKW6uJ15mkA3LSWPD9k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1082,"st_w_id":1,"st_quantity":99,"st_dist_01":"upLK50ZIi8i7jwP8vmOhlHIL","st_dist_02":"jbDiMQQylM99m2tNcl949hYm","st_dist_03":"ZqJQt6K8WVsJqXGbMHMrlNTh","st_dist_04":"LwHjruzpy7suqEBuzDop47u2","st_dist_05":"yujWN1xsORE9bBxz8b6gF3KB","st_dist_06":"28BtPn6b9d91buDeJ43wkPRQ","st_dist_07":"zdCHE5S8RTDVAiI6fU5adrOn","st_dist_08":"DIa69JJ77JedA3gmcx1yvjjb","st_dist_09":"zyNlA72nyqYZcNrszEgF0rl8","st_dist_10":"y9qUhPfTsF2aJyY2NVkdROL6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vJbsvcGUoriginaldyUF66113BT6LhLthlnKlBC5N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1083,"st_w_id":1,"st_quantity":25,"st_dist_01":"8S0u7P153LHsOZoC39RdcYDy","st_dist_02":"iLFYrcEjfl125SBfHTiKAOV8","st_dist_03":"9iLI5jAooV0IG1wy23Wi15YW","st_dist_04":"gLbBNZDXNyf8GFQMFAzbZyIN","st_dist_05":"3DSC7jzX4Ag3v3PFXXTxOT4v","st_dist_06":"BBQ3MeftHTzsdWOKakmtxFRT","st_dist_07":"n9TJlrOrgbc6OZEehQfCgFpR","st_dist_08":"ZskgXVlx1ojvsStnzX6x3mwU","st_dist_09":"iVBgQvtyXKqHZlKICeB9u3HN","st_dist_10":"IisbzsnqyZTfIMlE2vB1y4C8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LGTK8DFFosBKBR1XkM4TDNW0zeASUW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1084,"st_w_id":1,"st_quantity":74,"st_dist_01":"8KqSJCEm0ZyWTTK5zmiYtxjb","st_dist_02":"Hb2vbmCLAmWvVSXrLnXL5PuA","st_dist_03":"cESH8u0fw0IVqJDq7qycIg9R","st_dist_04":"0oEWN2ldKr8l05BvOJCUSFX1","st_dist_05":"GCQUUzCpcrnSrK5geKf9quGY","st_dist_06":"SWXlB8cAkHjJnR6w0fyncPDE","st_dist_07":"yUF9IDd3ZQP0KsO36Ztbub4Y","st_dist_08":"QJI2JH2MF9ILlhDZEz0iZAYn","st_dist_09":"2zxTd2CKquVqmDdqxhvEozvI","st_dist_10":"CzwEBLtgUKRbFxeoCc0QTZNy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ovQ76hf9Rl4gMbA7VVLhvKIGzx8Nru0jCBLE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1085,"st_w_id":1,"st_quantity":29,"st_dist_01":"gLoggt59Fw2EaZwoAOzYGyTC","st_dist_02":"bWUWge01Yu7qbBKZIXLfj7v0","st_dist_03":"rdfSGObol240Fr8HDFoPUyoh","st_dist_04":"QHdzAUblu4kj51S2fmXGZl5m","st_dist_05":"iqzHT7CJyXtXdk8uqeRKMiIQ","st_dist_06":"xes3X4dC8nDe9q769L5mUR8y","st_dist_07":"NXKgh4Vj3uo3huIcgKRJNcGf","st_dist_08":"F7AfxAX3rgL4g6HwxDJ2mIH6","st_dist_09":"5fgiR6Iy04VNXo8GhkotzkXG","st_dist_10":"fhTzbU14gb66kBZjQ7qcTvB5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1yHaIPYobEAxAahJpHVyScTpdRfScFvJe7ysUdbca"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1086,"st_w_id":1,"st_quantity":52,"st_dist_01":"xwS3bjVfRq6Eu1wkpYihTSYb","st_dist_02":"ghNQmY9Y7CgTHTc3ZJKDDsZN","st_dist_03":"oKLMmnPPt0lVZfkd67RYBJ5b","st_dist_04":"r4TKs5g0ViZeaXStTekIo9Hm","st_dist_05":"9MlAgXur3bX133UNktD1bKPw","st_dist_06":"8bOC5G8uSUi5k0pLlrTbbXDy","st_dist_07":"krFYN3kZ7Luw1FCxosYbMnom","st_dist_08":"xjr2Fsq46rnu8HgR0B4V6k9w","st_dist_09":"cu9rWVJfYBgX74Urr5oZlVq8","st_dist_10":"5WOjA7WQ1UXfolDP49okcTw4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1uJxNDQ9E06TDnvEwhIW6KZLUa636H44rp9gGniqy2A2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1087,"st_w_id":1,"st_quantity":82,"st_dist_01":"r5ZONEIQdiCz08tgcZ6QBkDc","st_dist_02":"Be30ROoEJRLZI7tvRwT2rSPS","st_dist_03":"00MiyZXqIjg8IK9ShrZXMWTE","st_dist_04":"0MI91hhXfXk85bdD99YXlpTA","st_dist_05":"woBEHD0Bbgt1VbxLgcSIlOCh","st_dist_06":"U9jOxLR9Jmvwc9IiI9H3hNBS","st_dist_07":"rQLZF6nVRPTKQcB0hTMPnUoB","st_dist_08":"6C783RO20IfmpDJB4jLlHGi0","st_dist_09":"BlarQSZ7IGz9mQNM3gBZdE1l","st_dist_10":"fcxYCWWqtb9ZE4z99DpuwtrT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Vryq9buaqI5nRBCpDBhFgFecUK1J"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1088,"st_w_id":1,"st_quantity":21,"st_dist_01":"5ucCXRb8EhwcG8OGM771Bp4E","st_dist_02":"zU8YEKDm9Om2AwKcWZ7odaUj","st_dist_03":"DiKdRqLkAByuOrP4s3mnhwUA","st_dist_04":"N1lmeJKUb8kbfpLAnSLpP22K","st_dist_05":"GNT565TKbHnx7rapVV1RClSn","st_dist_06":"GhQk6mmsoO6vg5ZUHMMeAp9t","st_dist_07":"kOgUsFBA7RAthYobZNEUpP3J","st_dist_08":"xEBi2jgEhK4nHCd1JA2cPwpp","st_dist_09":"p4idfGsNYt4DkmCNUNkXHWKp","st_dist_10":"Yl3sXDbHToUoRsfUHfHy0G5z","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0kFtXLZUgSxnewsUEXC7pGZ5aaP0Dbt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1089,"st_w_id":1,"st_quantity":28,"st_dist_01":"tbzHOnqTPCEMrYig0rzA8Dhz","st_dist_02":"AC3Vrj05EfMeY7krOIODXZrR","st_dist_03":"E2qq14DvDHMGOqHO5DZpFqaB","st_dist_04":"7PDVexNp2LwdL5g753VwbUXi","st_dist_05":"6yAaNx7s3AIOtB9lMfXpKy7C","st_dist_06":"xHRiswjJOJI4K1TkCXd12qzz","st_dist_07":"9cwmfEvuy5RVLvMfMLak1jhT","st_dist_08":"FEvhTotPfbL6LSeXrty4xh0A","st_dist_09":"Qe0EHhbVHp9P91lRN42nueNb","st_dist_10":"XFSm6PR3D6mfjXQZJM1cuQK9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qGCtQQtB7hHPGBPRxcNvWzUKfvL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1090,"st_w_id":1,"st_quantity":13,"st_dist_01":"kzyd27Y2BmNG8ssCW7GSUeaK","st_dist_02":"AFJps3KKvzR2PrAteebdoIQ7","st_dist_03":"OnkbD4XA4Xogvc9Wjujm4ZMo","st_dist_04":"VU3Gg8fl1ky5ipULuZlgIQgr","st_dist_05":"OlyeOtUC3Y8yn3uUwKYe7Je8","st_dist_06":"MCqUCJAdzOJpTTKvBt7zErJk","st_dist_07":"frSbR8eOwkznKvL7N3L638ln","st_dist_08":"sOog0o3R8pSWWufiS8L0mzLg","st_dist_09":"LpDDRDkqPzy1HnXzjLWPdgpT","st_dist_10":"HBpL7khivjleT5DpArGCTkrh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qdXJ3L7AzGxuD2rOZK8jA8KvtM9XCVnuhkiH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1091,"st_w_id":1,"st_quantity":97,"st_dist_01":"cEIFxcMTLEFqqIFsaGcKpF2j","st_dist_02":"QnTaEUHhUoQ9LHUw7WQWuX6K","st_dist_03":"m04bfoC6Q3thb3b0mggf2xIl","st_dist_04":"yyxWB9Z6bMQkpdQrkCnCMVV3","st_dist_05":"FFU8TDV0d6PZwRH08muIRNBP","st_dist_06":"I6pdjjUfWZYrnSM6fnwJ9FMx","st_dist_07":"7zpkZ8SK8XA0ycSuWZpjTJoN","st_dist_08":"17SRNDF06hSImvDcTHmDgrau","st_dist_09":"zkQCSRFP9ETyxHf07ywMMkOf","st_dist_10":"mmMl51VvnkwGgtxiiICdNGiB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"T0gOJhWwdogglupFjmJShreXn7FP0F7Uf9MYIDqS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1092,"st_w_id":1,"st_quantity":100,"st_dist_01":"34ut2KnU5ZJGc1WqnjDI8SSd","st_dist_02":"AOaqPmvCLShLo1G7QsXN1ZoW","st_dist_03":"LubebdppBi2M9jy3Lz9ggqjV","st_dist_04":"hzTzHlvx6gPFP9wwZxVPL9M8","st_dist_05":"5aC2bxdmWELnNlFBLLuqwlTH","st_dist_06":"iyQ1V4dpyytxlIwnaRZWW01t","st_dist_07":"p3BGVdwoWmioa4EC4rUAE8t1","st_dist_08":"sLQN5Uxj6YRYTrNmzUsWVkI6","st_dist_09":"viUTGAVwIFB5Ck2AdxMFNKQg","st_dist_10":"bJAvlaZ826JRpq2B8q9Xpg8P","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lRiTDYvJFpclPMeb9zAZVazmaPsanZVNF1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1093,"st_w_id":1,"st_quantity":46,"st_dist_01":"XUnC1iRDaujIbGA1bT3gA9DC","st_dist_02":"cwew3SeWpSxLripzveWIz7YR","st_dist_03":"sO88VJtV0ypKLz7aPRKWZkQI","st_dist_04":"oaJgW385yJEc5loZLezgyvNA","st_dist_05":"2mFPsMMMF6J8aceWCc2YjGpg","st_dist_06":"aq3k6znwnahnGsvcxIJn0l99","st_dist_07":"KvNg3YFmutSRm6ZhmKtBAWSE","st_dist_08":"ADwbVEPwd9edZfvFRrKWaCRS","st_dist_09":"JxDWoyybaspCLrgwr9zoD8S9","st_dist_10":"QUXZI9xKE39ZJNVTTZ8RJPfl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EuACE7W4W85jUbKO9LQ6s5QOkQY9XLf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1094,"st_w_id":1,"st_quantity":11,"st_dist_01":"m1No9d379fmaJwV8KHaa7cCM","st_dist_02":"zJxhXwXD7maQP4yZ131ssbU8","st_dist_03":"7YYeg5N0y9olhXIYFdYAcPwo","st_dist_04":"H26wROJGZwTY8i16qMYT0gkr","st_dist_05":"TqytNoNNfJLrkEArDxMaxyK4","st_dist_06":"SxBSaExSnJf2HIeIqyBSgZhn","st_dist_07":"HwSJJG42kF3uKz1tHsQEPVC8","st_dist_08":"dD2c6Js0CKeShv7PqEgad7Sv","st_dist_09":"PaTXVlAFv8cKYwmzzGtmCvJY","st_dist_10":"WRXJD5fR6kCPzEvkNcKSj1wM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ILjtsjmS6vWmmS9SHRjdNGHHPrMMprJh6PjR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1095,"st_w_id":1,"st_quantity":87,"st_dist_01":"TQy9CANMA1omNeqQYeaNOTAs","st_dist_02":"ouSeEghO5cFO9VupW3eDDkev","st_dist_03":"IL31lkL6Xp72c8fkn9Rps8O6","st_dist_04":"KWTiGTK4TgjyKGKrThKpp04T","st_dist_05":"cYaAWzm3kjxC9BAWOWZegR7O","st_dist_06":"vBjmFxwPS9CgKzmiiKEA22ZM","st_dist_07":"qwWMTpLAr3JBvlTC7Zy9uhh9","st_dist_08":"wsoZKRdxZ3elrQkrOyVKre2G","st_dist_09":"QMqHFSJMjE7rVnJKu1NeyPzC","st_dist_10":"FracO3DrMMovIJuENB5RVZOr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jsKSvA02obKm0YEslxm8MwoVDU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1096,"st_w_id":1,"st_quantity":80,"st_dist_01":"7KK09VbUcTISYdELzIkDwsPa","st_dist_02":"ZAlJiblBBqGljT3bfomlQ2TV","st_dist_03":"gfIGHvPEBZUmKhuZU0O6xcsA","st_dist_04":"yVYQuImBxRetrG7ilBEqdmoL","st_dist_05":"pBZ8XX3WZrPwnPdViXNOKAsi","st_dist_06":"y1Ek86bSRdMbsssgJYLvPELj","st_dist_07":"vh0aYPIpZvACcLBrbxw7BbRZ","st_dist_08":"pHlEKWKFXejjXkglNMpzUA5L","st_dist_09":"ePQGTCadgPdTvAaThTxL9Ggs","st_dist_10":"HxceWm4y7NRDdWskQ62Sp13l","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"im2pEUxFoC0GZzUaNUlIRZUZ5IDd84Hg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1097,"st_w_id":1,"st_quantity":43,"st_dist_01":"2OfWsip4gIHOlm8HTEwgKI4j","st_dist_02":"0Z4b2YwSJTsX7dT254x1euRt","st_dist_03":"nLpBPv01hMQUpwXgfCT630ZR","st_dist_04":"JWEY5h5DlhmGygPRq7bNsFof","st_dist_05":"H1iqWIBDsRSCB8t55RKbQBRu","st_dist_06":"qYF5yM2TEKykE5pbMdE12meD","st_dist_07":"R8d8o1e2raRiWi8gI1HwsZ8g","st_dist_08":"FLeAoVBAQtWa3RqJ3FNWKNTf","st_dist_09":"s6S9Glkq1Fw9rhz2r3ebd72A","st_dist_10":"cPjkxIxdJLut5bBIy55wVW6o","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B9UHbNq5dGUawFuj1BcnqhTBWY2gRmM33tWRNXr9bs9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1098,"st_w_id":1,"st_quantity":43,"st_dist_01":"AB7xYqaRWDxKRyZYufyFf6m0","st_dist_02":"Ke3c5fAQevellVujW6Nyi1nC","st_dist_03":"BXTtGFHiKE8bm9i0enIVy6bb","st_dist_04":"OHwNwOJJRDxLg4KurTL0iQIk","st_dist_05":"lChy383bFBTTPBX6BBkm4Bjs","st_dist_06":"qi7JZlFAhO4XDyj0d82vYbVi","st_dist_07":"KKgHemLYuBdvDm064gcWLjSK","st_dist_08":"aHIF8eANBsaNenPt3PkVUA0A","st_dist_09":"17JbQXsOREEqSFXi0yjISZDd","st_dist_10":"Qs2GRcuEhuNISfK2or5QfsAs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DqeSopW9j3160PGzXZWQPg9Nus7wSp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1099,"st_w_id":1,"st_quantity":86,"st_dist_01":"GxmLQKqgPkRWffAb4uLcwesM","st_dist_02":"6G4Sox189DXH9j5BEQvU4K9D","st_dist_03":"E64fxE2QuzUje9ZRAf6f2Nr4","st_dist_04":"hECDoUtckSo7Ib7WrS4lVO8P","st_dist_05":"hyzzS3oxnwrU8z7VA7yFSjpe","st_dist_06":"GYhEiqxOl7b22NOVb06kGHE0","st_dist_07":"xPhsrUqKykqL72wFJqyb2V78","st_dist_08":"cFSx7ppbk7mtkABXf1gycIbE","st_dist_09":"Jq35ci9klhOtJACafykNdfK9","st_dist_10":"8wCvsuHpHk0A0QC0m8o9BpWr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XWUxKWYVGuGMqSqF7um9FCMthH1izMT44uWgHlECO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1100,"st_w_id":1,"st_quantity":41,"st_dist_01":"BJt2trkVs5hnhQksqhfCL1wv","st_dist_02":"agEVtpgwFhV2S1Z9gfWPDNwK","st_dist_03":"x26qoHI8WKg2H8fQ3M8T7s6c","st_dist_04":"DbA5ZvnbHAwXXYcRY57t5CFk","st_dist_05":"V2doHHk5pGfVKoFR6BE7rDSc","st_dist_06":"X2kwlFSXyjW9mEaXKfPUxyoa","st_dist_07":"JUHscpuloBkFsNSgoYHvFdSs","st_dist_08":"6ZOG2GaaRwSzR1FY3NU80R85","st_dist_09":"Uugi8GNgg95BBXh6HA4vhEzn","st_dist_10":"Adim16pBpDk7otNv0vDP9fih","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9JgIjJY089T3coriginalBt73qD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1101,"st_w_id":1,"st_quantity":23,"st_dist_01":"mbQOxHRqDcAS06Btld91cpd6","st_dist_02":"g4pFcCp6zkUrgnTiU2O91nfw","st_dist_03":"YbHRFa8KbVF5SPJNxDWIJCGU","st_dist_04":"nHZoyB43f9UpMpknLgrkKb90","st_dist_05":"6hJRFn99u8q9Rb7QjkARTJAx","st_dist_06":"2MVctgQwTCKByXyINRaDSHHZ","st_dist_07":"stK9hY5X3af3MEdn7II5BkYo","st_dist_08":"8y8UfQUGuFuJ1IwCVvIlW2P0","st_dist_09":"EMGs5OCUwhEi7Wzr6Bqwgti7","st_dist_10":"4hVIN4G6flErZgww2KlQyGiX","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YOADqD6LaA2WO72til3SF7jYmmd4JmcDGUMgaPHPC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1102,"st_w_id":1,"st_quantity":99,"st_dist_01":"Ez9Wm6lJ9NLfszqmDLQWtP24","st_dist_02":"RrtVc4uRVdU7GhQ7AI0q7xtD","st_dist_03":"iSNRznuVCcmOtNMDK53O5wiR","st_dist_04":"gFy5G7WaN2Hj9351l3zYVrXy","st_dist_05":"8IcU9KV6bhsuWMVJRWEFs8fp","st_dist_06":"vvFfvlWwOpYO5VZMhkkQWLBw","st_dist_07":"SZQijp2rtBUqUIYONbo8mSJ0","st_dist_08":"KWbjSglz1jBbECEJ4HytjARk","st_dist_09":"czBLDXZcmmoO2hddBhKeJNqi","st_dist_10":"vCxh6ps9j8BgqsQdw9Z7UcSc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BAwqmpa4aQ3qgfCsyvIU1STlYk40omCkWXfM9hkfaUuaW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1103,"st_w_id":1,"st_quantity":94,"st_dist_01":"WLdZDhE0AVAhem53cjeLHORK","st_dist_02":"xzQygM6l8NDUPUP0nOWSd7WS","st_dist_03":"Z5l0SEcPJU8Y5fPXaCx0uUSn","st_dist_04":"vLXXbBjabu9Z3NcrEGGMHvWK","st_dist_05":"Cci675YFvULkgkfQOvJ7RmxC","st_dist_06":"BNeTZcNHV2vuGnRwt5b7FxjZ","st_dist_07":"uROFV4XvX2iQmxUhkXXGnNpJ","st_dist_08":"QVMjkuCCqrB1066MXNRtQoWQ","st_dist_09":"4Jp6ijqDq2mLr3uqYwHqDg1w","st_dist_10":"z39ByP8FH7WHAPUCn5hlsk26","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FoL8wbCrCrIaHOy5GpQCiwTun0u2XpTjShmebiKmVnifQlz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1104,"st_w_id":1,"st_quantity":94,"st_dist_01":"bNP6fHPuPx3XgshqzhIX8SQt","st_dist_02":"GTcqDEYiMg0h5zkyZmU9FqZY","st_dist_03":"s9EyO0nZVtM43bfZTzITibaP","st_dist_04":"6gyfbor7VDXOXbjpOz8ck2mL","st_dist_05":"Cew4biudwO5mVINQDWpmjgeC","st_dist_06":"IV7qfTctb4brR6mwy6YEmn1F","st_dist_07":"ola8kA6kJ7ykXJKEs8MXnhef","st_dist_08":"BrZkMA1nHTRxZxV19Li6TZC4","st_dist_09":"UjhbZEHp16ZF01v3sT1ASZ9Y","st_dist_10":"hiEet9sjpBBPceXKcZoOijkm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"d4QnWTkUNpqWlxrAjMqsgTjrUaaj8h1Qa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1105,"st_w_id":1,"st_quantity":73,"st_dist_01":"nA9wWdfmEaeMyhpleuPS9H7k","st_dist_02":"xW0Gv6QahgGfmGlwDxYJqPfl","st_dist_03":"rXVltCYYPUaQArpIznrkgEqf","st_dist_04":"QUr5pnXXL2xMfzNGPTbZ3YYR","st_dist_05":"7tTkkcGCr5xoPh7vBwVPePgb","st_dist_06":"rC4pqmT7YQ2EHEcOmLZMutYS","st_dist_07":"Ax6BvlpgZLjARuy4SChlSVST","st_dist_08":"zjtbFxnBHHPAhByOUvXFZJgd","st_dist_09":"d1mwG6OSY7cAEYXGXVdkVZCz","st_dist_10":"M9rEDi1imdrSGxx0qOz5ATB7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7Z9rRODvgQxJdEfeLsq5jAPlDUWoy3WVttT2plvxI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1106,"st_w_id":1,"st_quantity":15,"st_dist_01":"6QHyxK0yYQd5K9F81HnS08WM","st_dist_02":"MGeD9iKuI4UxfJXUsBdyw6qj","st_dist_03":"DGO2o3SuiMx7JSOjvQmIlhup","st_dist_04":"87qe1hLCtDmYhgJgXwJop8wx","st_dist_05":"QW8eewLh7baCPCkX5YO5OhHO","st_dist_06":"9nqCk2gB3OnOkTZ6n4blO3zv","st_dist_07":"TPQSaKqnIIR6oc2qVLz95L1T","st_dist_08":"DVf7Aam2UZExMOe6jPpXIQXp","st_dist_09":"Jm2GS8jzZTLRDUTXkDOZY0j0","st_dist_10":"SEGfqu5VcZJGFbYfTwlw23UK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"K7QrMGb0lhc6ZXiaEEeZc1apG5AjLcoufyLhN4JV1Gd7QOT6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1107,"st_w_id":1,"st_quantity":12,"st_dist_01":"IkpRPOl4oipwY4WmW306jzAW","st_dist_02":"a9MhZ9GxpKCqfCSLDXDOSpMf","st_dist_03":"99uNBJY4w1L7gI9JUqaVetFC","st_dist_04":"62pt7OIKzlVFmuvX6oRkSmDX","st_dist_05":"8LMwDCZlntFvsl5pvDQGpdWW","st_dist_06":"NoxgatAl9k3JNEMFk8atCkOf","st_dist_07":"YiUKP8qK9uRpYzWb8VyujRUH","st_dist_08":"rh7nU5hb8UfXqlh0qh20Xfzg","st_dist_09":"2pOPA4goWPDoP0cNUSKQOYKW","st_dist_10":"tnovURp7XtR57fafOpNMXVJ7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"amg2tLoQq6QAQCD4lCuhmfps5QAuZNZxQAMIUd9E0kM1QxK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1108,"st_w_id":1,"st_quantity":80,"st_dist_01":"JW9NtkPOMbiHOlvETBE7e1ks","st_dist_02":"SzKpYEEhltg5CEz0adRcnTmg","st_dist_03":"Ioa2H7ML4PbVD9rTdLHTr0rE","st_dist_04":"gcRq9ds0Nr6cfzb0nFdx6zAG","st_dist_05":"YpV4euTVRmg3fpXxdwPEDk64","st_dist_06":"1ZkPY8dZ39mmmnNxV9LcjrQo","st_dist_07":"AOQO5ahhz37KFqJ04Yad5vWr","st_dist_08":"LMxusDp3IXgIvRJcjHYc9Ikd","st_dist_09":"hhRkHhmfaag8Zx5ATU6EUIqe","st_dist_10":"MjE7ZwXXgqoTvwb50DtkQroH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t1OdJXnW3Q4q579dbY3HV8evG50uld3B7tdX4HIPxQOKDXn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1109,"st_w_id":1,"st_quantity":10,"st_dist_01":"SVEb49snXFnnPaqOgfHUeESs","st_dist_02":"Lmaqz069JQqKoDe5Ay3bA7Ue","st_dist_03":"DQ4EjnEHWV5E6Qefp93ibR9C","st_dist_04":"HvzvhoLN5yzTDTb2DSo6sjsG","st_dist_05":"xUdvIi2YvFCVxIzB2htBiLzf","st_dist_06":"NouAIq1eYsaZzw2bjQLbjqYO","st_dist_07":"aO0n3eogZl0pdlJIhaSTW0Tl","st_dist_08":"SILSVgl9B2o4C7wSt973E36f","st_dist_09":"Aoy9fEk6AieK5KrBXTX45b7o","st_dist_10":"Uu5Uum54v9uxRgyf50w3IeMR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"owJKePbOec2LRnMkttSRxcAJGuDYaWe2yYRMPTDSGrsqgJ1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1110,"st_w_id":1,"st_quantity":47,"st_dist_01":"F8MKlqBmB3Ky9o50ozgfzCJ7","st_dist_02":"PZp7NEoqLl339J2HByvztvUV","st_dist_03":"1Og5MillUgqjImjCVjsoKINq","st_dist_04":"T2TNeTmA13ltSNvjGk7dJebT","st_dist_05":"yFQIbsnckuY5Uh2A5MA6MT6i","st_dist_06":"hQfDUIsOn04GiVw2HB064ZFt","st_dist_07":"mMLLG2lBTqPfKFVCmSPVpumK","st_dist_08":"mnLUf5DtqRo4ElmGyTuPXj6D","st_dist_09":"gjig7ua8siGrkZbM1XZECOG0","st_dist_10":"8bcSBHBRL6Kikn2adQi6MWrV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"weWVZvROOvyaoCVMO93FMCgeQFMb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1111,"st_w_id":1,"st_quantity":59,"st_dist_01":"OSdjErDiBj7q0WygYXrOLm6E","st_dist_02":"V68lDYTDNOdcXsM08Zuvhw7O","st_dist_03":"T2zqfXA1aAKrUmUG5mPqWswk","st_dist_04":"tQgPna0kMHffwGsxRPDLeDcn","st_dist_05":"8UBYoPnG6fvvE3iiidv12ktJ","st_dist_06":"C42T94XjUrP7RDCdRp5uFJOz","st_dist_07":"YzgwwBd58tsWPFo5QrYUeBrF","st_dist_08":"mRczzftO2cfWcROXWjlEMyQ4","st_dist_09":"kzI3OvavcIIdI5AuRBqLZviH","st_dist_10":"bRvADnFoVOfKrqJDirjLoz5a","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Eam5HxlS0VtLCqoCW7dGFv8irJTyZzZEouBXywksRZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1112,"st_w_id":1,"st_quantity":96,"st_dist_01":"Ru4aZ5BA9wO0kr4UFA00vCHh","st_dist_02":"w4zWBvqowckEzYqdbaRCcxv0","st_dist_03":"YBqnvNphPKUmLGjBHjwdn3w7","st_dist_04":"rJvBtSTAmgrFF9V9Z7rm5kqp","st_dist_05":"OoILyGnIFtj1QA4MJ4htBlFi","st_dist_06":"6FFxR2w7uZIajkiYPJN61jMN","st_dist_07":"vmi8eAeJQe6bzEm9jjtyGtwv","st_dist_08":"GCeZArtb6iEHfG19gx3uY1dA","st_dist_09":"U8b3tqrf1DwDCHSthp1KnYqZ","st_dist_10":"gYL7SN0zfShKXrd7pcaqYjCA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sVoESs5l3PJLgnb2LcyGWZ2jh9zpskiS5ivQFH9Elu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1113,"st_w_id":1,"st_quantity":53,"st_dist_01":"kPsATlz3SQVhNzb6q7vEJuhd","st_dist_02":"Jplr3G0kOe0YnKiNNVYOWstd","st_dist_03":"QpSBA007IDT20P7oq9HGTfLT","st_dist_04":"YwBN1P00pBUfHG7HVZikoKEI","st_dist_05":"EijVCdS2ALCuBb7BVotJczny","st_dist_06":"xqBUvNZz492PQ0xhUl29q890","st_dist_07":"heYHDRDWDKhYQxrYodJPJXw2","st_dist_08":"qJqiKVjbOjHf7eSeGFhVgdv6","st_dist_09":"xwqDPPhqCg5u8JrpxswyKGG8","st_dist_10":"dXuUVyWpqOfs4OGnjSO1zEDz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RMOlVrLAhbpxSTXPYKxPOkkIcWqMzWRPtKRWC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1114,"st_w_id":1,"st_quantity":22,"st_dist_01":"hOXeGpih0HUVxPkrxCnrofGw","st_dist_02":"VT43Icq0JX78sMMK4js00yQx","st_dist_03":"sMHPPqFxOlEimiKAd5nZIDAo","st_dist_04":"5m3ds5sRxJuReL3xGnFDvdnI","st_dist_05":"HFlqWpYYXRex2g3MebvyCPw7","st_dist_06":"CuKQQJGARKnXOA4iOJ5J5AaJ","st_dist_07":"zDt6FAu8b6Okzywl3s3NQHqx","st_dist_08":"NuOAE8HRSfnAGa3ieF2hfyM1","st_dist_09":"dY1TUc0KIzW9vicjsTXT13bj","st_dist_10":"Rl5wtI43bhqzVShUzaOPMcGz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B299tWJaR8ddqiVrWuEmMCbBHexi8OIL2SFn0ejnp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1115,"st_w_id":1,"st_quantity":89,"st_dist_01":"9IFs3Jv01oCI0FCJRYM7owRH","st_dist_02":"efWQMrlhguzGTtvU2px6Jm6S","st_dist_03":"TGPkCEwMrkKJxJuYQs7AuNJj","st_dist_04":"h6ETknvneJSt4WQqnbMnn2zc","st_dist_05":"nnI6LDYaDj01IzQwcIU9EXD7","st_dist_06":"DF8ikclgnAnQD72uJPxtTwow","st_dist_07":"0GhgNbgP4e0DCPuuiddKF4ES","st_dist_08":"kJQt2OKn1PbKff60lXs3wPxu","st_dist_09":"mg0611m9ietyeqRmoujL13fx","st_dist_10":"Av3KodablLKHjHVtPQPLjX1y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UX2arq6ftj2iBoriginalM4WpL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1116,"st_w_id":1,"st_quantity":29,"st_dist_01":"QYo1P85Z3eNQ9fe0x2xLc6GF","st_dist_02":"1cLcaorNZOp75whhfPN47sKm","st_dist_03":"vQNkWRIicLhHHnX5xcxlogca","st_dist_04":"tp9Kukg0b2GiNwnoiemy5e7Y","st_dist_05":"14DnbPX8bht0v6CkeuzzA5pJ","st_dist_06":"OAm6Z9WC6zXflJtz09mX6NXS","st_dist_07":"fH89StR5mcSZFoOcB8Gneccg","st_dist_08":"dDQgOuy41kwUU92G6o9mKuoX","st_dist_09":"vKoAMIuDNxTqsFalVKz2JgyM","st_dist_10":"dmmpW2CVve8dLROVNOG0mCcC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7y6cRaI6lKKVoRQkwEr2wmnKPCFEvYQUPbvxmHXPQVTlx9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1117,"st_w_id":1,"st_quantity":12,"st_dist_01":"7ntraL4FUSEaA1zwSlZl8eU0","st_dist_02":"ucMutFSXVtG0FZD1kjHdge5w","st_dist_03":"vl9hnmLUGYWdbp74lzmqj3PX","st_dist_04":"Oj3jEHPKIcRM782PKuyIvxc5","st_dist_05":"iyaXOWRRSZsHbBEd5fHqJzyV","st_dist_06":"yiDpZ6Z0nWs7GWxy7kbxWYct","st_dist_07":"pX9zr9t21Sfp90nKbunln4tK","st_dist_08":"E3AE84wd1en1ePV81WLIrfNf","st_dist_09":"Bvtc6UVYf3LdybdE70tNRmgj","st_dist_10":"eZV8ePXpmz5wyHs7djAIHUVD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3tM4KHKkwbkVKerNPwXaSRQDtuB0gZB64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1118,"st_w_id":1,"st_quantity":99,"st_dist_01":"ZkSbDl6fauSUptptY58NAM78","st_dist_02":"WB18dGePDtOox06pvqbr0lht","st_dist_03":"XDBNEz1BR4vG7zXovokeeDkk","st_dist_04":"1fuhIMtQzP7bFqVYr7TfmPme","st_dist_05":"oiYaklLXkKeXeOiaxSahIThH","st_dist_06":"ik9AqQmjqTCBSwMzexnEqKBW","st_dist_07":"Hqst6oe9WtvGsSEv2PHUAuuY","st_dist_08":"FTPDj7yiJZ1PmfdZvKWiCA6i","st_dist_09":"9XTWK4JFOPt7FePgFnWmaYvC","st_dist_10":"OFiC4iLaryLZmmH7vPWLJcig","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"25qrXGA6V0dZgpuPn9wHsy4pAgaW3kdYz8Xk9Iat6uClYVhF8U"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1119,"st_w_id":1,"st_quantity":94,"st_dist_01":"tkCAekzstrrQzLE8hPh1XCoO","st_dist_02":"DezuPcSL6w37cr8KyT2L6cB3","st_dist_03":"8Zf3ly4CuSTrEKdiVdcjoLTG","st_dist_04":"iyM4BXTdmuMdDSoDf9SJiR3r","st_dist_05":"WwDj3OxfbXy7z00Yi9R8aRqG","st_dist_06":"4V6vfyWFC79QE6JwY5mTnyf3","st_dist_07":"gleywaoqDC5JdPTVWbQCCFQc","st_dist_08":"VePSKfig23MaTQNHQgD7oqTM","st_dist_09":"3aUDKGvFF4bELiGgitiKBMur","st_dist_10":"GgnAjEZ3aUncm3Kc2YAC0liq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZUxJHk4GKiET7fgqn58HJawcN6wt1kt0QOCZWcCW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1120,"st_w_id":1,"st_quantity":37,"st_dist_01":"4uhoEuRtDW7ghj4RLtrgNPB6","st_dist_02":"MmBgTNoCBylHX8vnfZUOdTFJ","st_dist_03":"8W4g1A5qoaW5jVrQj4EBIBxc","st_dist_04":"zmyg2HffruwG9Y8BUpVjJhZt","st_dist_05":"deGpbZoBitHouzZBCPdE5o5A","st_dist_06":"oULKJyxPAG0ij0sQuoTtjX5F","st_dist_07":"5shjjrqQVg1F5MnMk6V2kg91","st_dist_08":"pi8SnTIgE80xI0rjQxqvfvKe","st_dist_09":"RKub8ey4qOHJOWgUPFrAvtcO","st_dist_10":"2IRQPmheu6ndXZBL25klFjDB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ELqsY4pTAbzq1FkeWGvBONAiFG26oKtkxJb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1121,"st_w_id":1,"st_quantity":40,"st_dist_01":"yjVZD4i3inQaLybrRnjpG369","st_dist_02":"aMhIwfrSmMSA2VhsRKTdsnHu","st_dist_03":"H3D8Z5NL3RROldFkVLMDFKvz","st_dist_04":"poon5jSVkWzNBPoEK0X5OTOu","st_dist_05":"udrkVvvzSxAqCKYd3bo2kFeq","st_dist_06":"2CwMSEbaoxS761JPJ8gFkkAk","st_dist_07":"VKjKiU1E7vzzYNVwUpyNcM3l","st_dist_08":"XX5zgAkFBIcJnhh873LmfAiQ","st_dist_09":"Bah3g7hzWLPqIVCK5yaEWznD","st_dist_10":"o5XyMQENZWhrii7WjXpeFhD8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g3BWkiPX7MSQoB9auZFRoYf4hPcGBmREGdgQlApWI1bys"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1122,"st_w_id":1,"st_quantity":97,"st_dist_01":"N56Dy0XchuEZlV6NfWJNKHtM","st_dist_02":"qRCUBxQh1k0ccABV2v9MyNjo","st_dist_03":"ei4AAFKWLfgHptQJMMH2ccSR","st_dist_04":"Q0uZQnXiBqrt9P0P9ieTXx32","st_dist_05":"FIebW8skwWKoRCHwmQKzlFOg","st_dist_06":"zAFKw62cwUlXv0KGzSKfjsSt","st_dist_07":"DLQ17WQeNJ5AqVHt5DPhSiT1","st_dist_08":"LqDMJI3T6MYSkPfycVmDEyl6","st_dist_09":"zhXBUxoQaf9w7ObDgoj6RMDH","st_dist_10":"uIdqX2E5UI9XrDu6KLkZQdpo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eZga5PmXGdSKzxN1originalPv22Jfjd9YDBWbIMSamZJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1123,"st_w_id":1,"st_quantity":100,"st_dist_01":"ut2Jmdce9PEAiDQ2YTgQjvRU","st_dist_02":"7zvEU8rgcSbc4maPkMmvJgYH","st_dist_03":"juDss5jpwH3WARxI6GpxElCG","st_dist_04":"AhK6EH4IrpqMKliF4hcIE9E0","st_dist_05":"y2My72r01yKLT1hDNW6RcY9w","st_dist_06":"NmcmnJdTrssiqMGnxNvltaVZ","st_dist_07":"W69TElC5JSJuZcQwJxYowa1I","st_dist_08":"OElf1qB7JXJzCJPZDziF680H","st_dist_09":"o9kX1Q2E9K7cZch621DmNJTN","st_dist_10":"87DLaUcTaRN9sMPWIJbAQWZM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KB3Qn6P8YElrgzKsXleHGx36eWH5ugflVhuSxz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1124,"st_w_id":1,"st_quantity":38,"st_dist_01":"VnHiscOnGNwXqluJj97rxlZH","st_dist_02":"wxACWTQqQQt4Sy0yBuwNTr8U","st_dist_03":"OcauZr20SNmvPauvHHJOZloz","st_dist_04":"Z9fZ2rVuocal4wafJXJBsC8E","st_dist_05":"psslmIyI2jreMr2Wur5DoN8H","st_dist_06":"e5IPNkh2OpHIXSfvpPAdhLny","st_dist_07":"b6HDoky4z3SkAJ9g2oGXn8iD","st_dist_08":"YmNFp0cABhQ4Da8V1p6XcT2P","st_dist_09":"wsxZdCeDhWWw4fL1W4hp5UTo","st_dist_10":"fhFwKz83VxQHTg7wDS68vSVj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ql0izSuQLErawz0gr1JsN4meZ9Aqj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1125,"st_w_id":1,"st_quantity":81,"st_dist_01":"egz65t5SnGSCKCjDgvh1q5Yg","st_dist_02":"OtHxQV6V0YdBlg3i0f16pp6x","st_dist_03":"aRuVAiQCd4XzrS8F8uCi2DDb","st_dist_04":"AkGfLEi9EwXJFJuFASS9fVFr","st_dist_05":"TsATtvLHX1WIfy2kv1wtAlYn","st_dist_06":"awjahwhSEJXk4pJ4z6Z29rIA","st_dist_07":"AnkeHz0EtBDlkFzQUaGJalPx","st_dist_08":"xJP6aOshqBo3TE0Eli8SHm07","st_dist_09":"PuzAPvlrPa8UjX26n94ASa7Q","st_dist_10":"2mNRSfnXcLLzxKegiBxIEUYJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0AfF4WwDU3etoQVb1AaLVxkTTueCnHyh6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1126,"st_w_id":1,"st_quantity":93,"st_dist_01":"CQSS6t3lBKEvUOJ5gUrAC3UF","st_dist_02":"B5eXLrRjvLyay1nO4DgXPAjy","st_dist_03":"xrXSiA83ayaJ4di5JEr9aGKN","st_dist_04":"dXoCkyspJxpt4CMZCAsccXyO","st_dist_05":"ZwToR9eA7C0EOpzJxY5rGbgw","st_dist_06":"ZGg4BPohTzlwdJCSV6w2dfb4","st_dist_07":"4bgxx9hKW4F2qgvhkyk71r6h","st_dist_08":"vYuSnEVUuwiAra8U8ifAf5bR","st_dist_09":"VRxwAqrH81ZpMEaJOemiWo3I","st_dist_10":"DE1s4ikDz2d4TKM5mAgCuFwg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ckrs3jFpxjQxPxOK8nS52JVPv1Lgr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1127,"st_w_id":1,"st_quantity":54,"st_dist_01":"4L6WaW7CGoPwSnxPIBA5p7ZM","st_dist_02":"Cibh1widgIlgXkZg5t8qNvbw","st_dist_03":"VUC5KO5M7v6xxGVqloBbMtKr","st_dist_04":"YdGMEbNzTnXsqGYGv7hw58Bs","st_dist_05":"4p7cKVojetPIJK5VuZkHFgsh","st_dist_06":"ORn4pfg29tol475ZMzCgv3Dd","st_dist_07":"Oo1t3AzXzYV4E33jvuhQKzGz","st_dist_08":"yLApjmwEcJEaTKrGyqNfRB2K","st_dist_09":"7yxTNp774kNN5msMVh7nmj6F","st_dist_10":"Mk0zc9H0jFZ7J0Yyy5GEEiXA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QJP8c4EJnecEXBRp8apDJo6DkeO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1128,"st_w_id":1,"st_quantity":61,"st_dist_01":"OZHm1GyBYhh1mpAhcm51hWhd","st_dist_02":"ufLlRe1yaHO1LJXwormFROYL","st_dist_03":"lSCwbIsvIBcqd36zbKX4Bziw","st_dist_04":"ATp8uOg2o36tBRBlCt6zF2sv","st_dist_05":"F4D7jdoAZc7Hity6GY4loguS","st_dist_06":"EQBhWUEFwn3UIPKsAFSId3lQ","st_dist_07":"XGxSLRl3lhzjS7QmPvjMsd4r","st_dist_08":"jKhgpLfe63VkojHFsz6q0w8B","st_dist_09":"LS9otGmdAfUO7XaFZLVgsHss","st_dist_10":"SwmwFWNTzCvUKKbCl39WOuii","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VFT8eKkaNNdkSEbkQn6pbW9tbYwa2BzCsXCVjWWWIxiN1L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1129,"st_w_id":1,"st_quantity":57,"st_dist_01":"7LdjMzK8iuhUzoUrmC5wiGcz","st_dist_02":"BLN1eFqDMt8akh0INu6xeoWC","st_dist_03":"eiUdNK2IjzILD86CNoAu233B","st_dist_04":"B1mub0wnNDH4EVPNI91Xka6o","st_dist_05":"noSgZa18Gozk5NQ2dYVs8wsc","st_dist_06":"GlBY76ENaOXHVG880vl40pFt","st_dist_07":"FJF5XXZMhWvPVTlxSZ9oK5iu","st_dist_08":"ecGZ5g72n5CwyKLt5galjXTG","st_dist_09":"hlzYoHcZD0PVI5wqm7GIoTyT","st_dist_10":"MjC2N1HNd3ixaajZJqR3fZMC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RDHkf9QbrTMybqQobyxgVuIx3Z59C4IhoeggAlRvJYXmi9tnT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1130,"st_w_id":1,"st_quantity":23,"st_dist_01":"dJI0aQnnRuJvy7XeKNbp0YZe","st_dist_02":"QWHX3IJtiGui1TwsMUOk5wCN","st_dist_03":"EDpOI8GGeu3MBcV3TEAADMcQ","st_dist_04":"1XB1SLM87uXQGiEObguqdqHm","st_dist_05":"9UCRNKz2BBnnqmVIaTshaWwW","st_dist_06":"TSXM1gs6lQLxSJ6712hJ1cKm","st_dist_07":"Wt6PjoQiAlJil8yaOytk266z","st_dist_08":"wGsFTsgBQ3UJEy1pZPFpbPEW","st_dist_09":"jd2pAm35sw6ccQ4Cvmw1kA3n","st_dist_10":"0DaKiXsfp5ozDOHDwaRNr1U5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9wbadrJGrhwCh3W5MTisPIrkxJknfuHcZ0DfjVNLuvO671"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1131,"st_w_id":1,"st_quantity":29,"st_dist_01":"zqfsxjeuAwTySrSwJ5jjuYrU","st_dist_02":"dLBiIHAyTL8DJNGZK1vlsJUy","st_dist_03":"9M8er9MtNhfRLdzPIU8AX5fH","st_dist_04":"C59Q5SP9eNaDM0s3qNMJmr85","st_dist_05":"CoETcmhgKJe3E1HgzHXlVUKz","st_dist_06":"5NEi0aC50O3BUVmdpeOsHi9n","st_dist_07":"wbHRrz2jH2nM4QFVLbTiSgbI","st_dist_08":"mg28YMPhZYYKp1HEvU3OOvo5","st_dist_09":"ccwKBpONyv7uVLd4Bi4KF4WI","st_dist_10":"PGdV12kNs69D301nFhmRUc0y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"T4lNwUhS2SbgTdDutTD063meLOP0u2IFPPy1f"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1132,"st_w_id":1,"st_quantity":13,"st_dist_01":"zRyXwsWVCPJ2UUzlISZ0laLh","st_dist_02":"K9DRnTRejNjBU8EawiqF7VhV","st_dist_03":"lmT2SJYrF6e12Z81JytsKv0h","st_dist_04":"mWmWR8skbsPOawoDYTB5rdar","st_dist_05":"S45iFkECGJap8IMZWshuSwy4","st_dist_06":"PVEiflqzjftKcCZI5EhYXnim","st_dist_07":"j539tszjXjcQBoKioGqCJ9hQ","st_dist_08":"evcmcoaLPZxbqckDVJUQyGUv","st_dist_09":"t7RsSOgp6h6n8wY4aFSuq120","st_dist_10":"rSTI2C1YI17JzPGwT0nG3CVv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lZ0SeM337H46Apka81wH2OHpJZWYYNNa4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1133,"st_w_id":1,"st_quantity":45,"st_dist_01":"s1wp4pfUoROv7MimtKJtYJy2","st_dist_02":"zn35Fnqj6GlmBT8cv5Tu0OIG","st_dist_03":"4Zb16Z5lU13X1m1DQdV4pgx3","st_dist_04":"rM6zoCR7aFbpJkGbRWJcIXxM","st_dist_05":"Uf0r2h89ed0dbB8Ocl2lMEbn","st_dist_06":"GMAIsnskpV6BsyjhVoGwLvRB","st_dist_07":"V7TcVjQROhnHePG0dWTrie3j","st_dist_08":"s1IhEPqS3ZF1uHvwAinVxYaH","st_dist_09":"SG8JEXFEl8WUQIu6RGMal5BC","st_dist_10":"GE4UCC1OIm7BO4yiVhL1VJPp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9Ikf9qWxqrrSveqtpUXTjJhjB82ykTW3GWWxKgqurjvT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1134,"st_w_id":1,"st_quantity":11,"st_dist_01":"IKdQMgmXWHovlp1tMgP8DJdA","st_dist_02":"BrrhwflZaNmJ0Y2WI1s60yni","st_dist_03":"y9MpcMSxDQecrvb0iJuaZEUO","st_dist_04":"eEiFgdSB0eSVdHPo9UUIvTZs","st_dist_05":"iQCStrn4Dkek7KQTS1URqLLH","st_dist_06":"vb2UhCDrqFX4YNc7KLIA22y3","st_dist_07":"LGe6ybAXKUV5HGbivkDqmddk","st_dist_08":"u5TannjJJ5z3S3V5ZWDahZ5Z","st_dist_09":"PkH0tcW92YG5phuHKpM9QjRK","st_dist_10":"NJaTLOIZgQLpoViw7EB7J1Ii","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xELbsisfSnJV7fMoriginal8D87KO8BjBP2jNX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1135,"st_w_id":1,"st_quantity":56,"st_dist_01":"RFnXMx3G2EDqzE5jjuE2KwDp","st_dist_02":"Ek98CP4Li187WASEqYF48xr0","st_dist_03":"0nhiu9w2OSAQLMdx59dOYWtl","st_dist_04":"TJLfkmBembcqWM6uSGxoe2Sj","st_dist_05":"VhcKoaJrlaZucQUBlN0wFLQ3","st_dist_06":"cr9ZFt6XEO4FJ2ibhhBKIhVH","st_dist_07":"VMwA5D97NyoQgpcLazlXz81b","st_dist_08":"qGNOipTCjBtO1W7NpOpZDOqo","st_dist_09":"PlukhgTMfb2lo02BGTJMWcCE","st_dist_10":"1snIIJdYzg7J94ZUCYo6yzzD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fvrzYTzKlDzctnsOdI14J6bSugphGy2MCClg1znYDVsDd6oXl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1136,"st_w_id":1,"st_quantity":38,"st_dist_01":"yQGF6T2O5kP0YAEP5tgVQ097","st_dist_02":"at71lxIxMBvOB81E2f975y98","st_dist_03":"UyqrJbEmzo2dtIO4laLeQitT","st_dist_04":"xzIS27al5Tbwtl9b7lCIlE5s","st_dist_05":"lxH9hFt5IVnOj5fEX7VFlMuH","st_dist_06":"n6YPjQ7UUgmyIVayUeP93NXS","st_dist_07":"MQ0j2V09spLNBjue9EhTp15Z","st_dist_08":"ny2zFZ7xuRPsbSfIzzY3TuzM","st_dist_09":"flE2wU34WJD5I5BcLgMcdjqp","st_dist_10":"tMvwzqxlHZKIckuSYGsxdvWo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"k7CCoPpaxQn2rsdkgpemCO1NAag2hoVoDyMgY3jYSFxNb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1137,"st_w_id":1,"st_quantity":16,"st_dist_01":"82Hd1pcttWnwz3j8m6rRJn35","st_dist_02":"C8RHFnzc2h6eJs4mQU5KfEU9","st_dist_03":"sOqToGOZrQk8XdQ7G7BJ28Rx","st_dist_04":"tRCzQJjcFxO6h17PUCYy3Yu9","st_dist_05":"5SkYwTNCfs3h3zI9IBqvcajT","st_dist_06":"NUwdMdwd4olHhHUpQh563tyY","st_dist_07":"8iRKgpjJ7fTfkSjcQeKdzRXS","st_dist_08":"doRvfFxTSHuGbEZUzk6yq8i5","st_dist_09":"bisUc7vk3TDK7AznWNaEPjMv","st_dist_10":"aTs8yzoceDn0IsEWsOK5WWHK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4f1lYCfB4HrN736k3blapqz9p4rkH5lUwv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1138,"st_w_id":1,"st_quantity":13,"st_dist_01":"Mt6vWS7IqRPLORJrTJTCTFZX","st_dist_02":"35wMYYxyE8Ta6a4lU6RpaQP1","st_dist_03":"EuovxDiKbYAlS5L3T7pTaCIK","st_dist_04":"ikZt6Czt3rc4Y90lUQIufTUr","st_dist_05":"ycv6TAxwRL706GC7vAVvHpln","st_dist_06":"lQsdpuncEJmecrrEwEWGSjVt","st_dist_07":"2OibgNOtVsfyxuyVXuIpMCe4","st_dist_08":"s5RXf8KEW8IUERTE5Du8V5r6","st_dist_09":"iMP4QkDZr9kDvQIBwimyN0Lv","st_dist_10":"pdd7IdkI64GkMLRLqXRkmNvA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nGnyAwaSd7IJKHbLu059tcMfrd0NOnDqSK2g7h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1139,"st_w_id":1,"st_quantity":39,"st_dist_01":"PgeYOYo61j7khJEWqCIMw9LI","st_dist_02":"IUPjlleD4GtTakn0ywlHBm8z","st_dist_03":"IdmgEttDnBZKBibwNfpGCW9D","st_dist_04":"K7wf9FKjpkbuolg4a4TDf89y","st_dist_05":"EzTKZPt6ux9uSasFW1pzme4x","st_dist_06":"3KHEhC4c40Gg0gwzsVMe47W9","st_dist_07":"b3s9lmMnmwxh6D30ee6YYSEr","st_dist_08":"Ek3GWPbq1YsKjUYHkqH8MrHi","st_dist_09":"6Mmic9GYIzzrVgCsPSJgMhwq","st_dist_10":"nBTyfEKUkDIrwslYdMVsona2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uuEaMw5oiXMmU1gU3G9SPPWD0hY1K5hVpPY1Y16fUZFwJts"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1140,"st_w_id":1,"st_quantity":33,"st_dist_01":"w75K9bm6da2GnVN09vGvJMDr","st_dist_02":"lCrqxjbvpunBTfDpA7i4Fs4o","st_dist_03":"ZgXTcJFDrBoFzEzQMXVv55Dv","st_dist_04":"MV6nizcgPFjfNrTBUKSnDXK6","st_dist_05":"UL9cvc661fE96UH7NXdpko8g","st_dist_06":"miYkr976T2iStLzr6Eri52Ho","st_dist_07":"OWrCdwPLCnuznFWf55PoeptK","st_dist_08":"cdtPGghcoJin8yxXkz3bPo7P","st_dist_09":"IdZ41sRNDhweQs7fIth6hIxT","st_dist_10":"yICpilQRqxPCIsBSe5JhyV33","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iPlVlRBtvUcJBS3lUSwxet9ySwbUF0yQ7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1141,"st_w_id":1,"st_quantity":15,"st_dist_01":"yXDtyWEhbZ86UWW927Bcl8V8","st_dist_02":"cmw7ChRqn84HAlKm3ivvVmrD","st_dist_03":"HVB88pCJplzbhIZKrjkpvkw8","st_dist_04":"8lc9p2KJCzERTmwonQxgmWgt","st_dist_05":"b7sDDtWeYMQx33RuwMFmizmu","st_dist_06":"AqnwWoXt69g9nAahuTiS6lYj","st_dist_07":"KL8bEPlNODwSF6zOFzCaPgX1","st_dist_08":"lhjZIjfrw80r9kbJGP0wwykW","st_dist_09":"0e5jzKQR6LY6sKg4zPuMfFWs","st_dist_10":"hWkA7fGP5DljDKoLWqro1uFx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Q8MyAOQHhhvdEyCr1VxCFxxzQCAl0V0aZda80Gq3CkuPp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1142,"st_w_id":1,"st_quantity":42,"st_dist_01":"eoZTHLnwvRELFiKDUB4RcRf0","st_dist_02":"ZcGtbTYhCgxlOQyYLXfj9wds","st_dist_03":"82fPB6wSpUeGKM5UWo83IAzt","st_dist_04":"YNsgcSMJrbKX7LoRSiHmA0Jr","st_dist_05":"bCqw7Jmr2xknnRikpKnqzJgk","st_dist_06":"z8nIjQGCi4DzgKb1SwohqWON","st_dist_07":"c49zjr9mX4kxHcvaGoC7Fd0j","st_dist_08":"ZsfoCpWVZ3jpaLGiOXAWUGHa","st_dist_09":"wHfKLbAtsN9D0RpZ1vNoUhrl","st_dist_10":"DFZeETHWKWMuHeyIZw4n5Ii4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ysdsbnDz6BKn5zLrymlPYls7Mi1bkrUyWXzSbs5anreKI9B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1143,"st_w_id":1,"st_quantity":77,"st_dist_01":"iQwkhZFgC1rBoXXjj2WzKZjx","st_dist_02":"0V5SBn06vOL2Eoph0wG9Jgwp","st_dist_03":"GCJbNOzhmcdTkTH93gw8eU0V","st_dist_04":"pW2lJVkR7fZphExcxIimHpr7","st_dist_05":"KwjIqWV9GKePcTUB8RcKCZz6","st_dist_06":"9VEGfk8OCYXnoEjtlemeqGEr","st_dist_07":"rT1crkoTry4SELUXckmykaMl","st_dist_08":"1AWHGvF3zDXgEQ58CgzCRFwT","st_dist_09":"XP2ApkfJwsBKb8pDzhkaCmON","st_dist_10":"TLsHZT3m7LBtWG4Uuv2rmUO5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dDnndW8bTZZ3A7T70m49UdnVFcdBzg7oq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1144,"st_w_id":1,"st_quantity":96,"st_dist_01":"8YEOmpvAyWH74nKKZaXB6NWl","st_dist_02":"Ad4yfrJeoqI0pZ9TZdtryrvH","st_dist_03":"tDyr1HQA9E0eQHrteDvby61P","st_dist_04":"xK1eqeDKcHivRbyChVBz3xqd","st_dist_05":"vf3mvgxzGN0aO0XyFPt127u6","st_dist_06":"6MjUdVwoTNHhO3uowndasGph","st_dist_07":"xiR7e74jHJ10LdTve3DOoPjW","st_dist_08":"MPXMMOnvMGEOMGm2Q5vR2cod","st_dist_09":"yiAe32e9CsEWpNBaG1xxSCiR","st_dist_10":"D0l5Tj4pqxI7QOejhp7qFb0P","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TPqPAeR0TYUqk6oYOKo68sNujztzOjPzHiw6S2Oq2lCx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1145,"st_w_id":1,"st_quantity":78,"st_dist_01":"sTQlTPOVyvXHVgPxTHa7sj5C","st_dist_02":"Uel9Xs2DSO24POi25puCLd0K","st_dist_03":"moskDrtvr0DPin94PBglyic7","st_dist_04":"mEFJZ48EEGZHqI8MaeqRfkiC","st_dist_05":"WKQfyJz20w384gG92cWYXPjo","st_dist_06":"GBeYXTx3aNyyX5YSSYod0GIh","st_dist_07":"BgUEmPL3HZuiJLF2P113xXaT","st_dist_08":"fDIEXR2n1YAz9h78QNWZak15","st_dist_09":"6g4k8FkG841OKd7EptAo7K6U","st_dist_10":"K7qy49NvblSnvXqLU2ESj2hH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GtCyyAcDykfxnPjB6MkJ9523S2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1146,"st_w_id":1,"st_quantity":87,"st_dist_01":"V0doeyBLcbSzbY4bGPiuHHHc","st_dist_02":"D8z1gmj185YrvyecDy2VSwCW","st_dist_03":"oSrlW51FsMBGln3S6X1Xatoi","st_dist_04":"QrPAmRoqbcwD0QruYWqpiK0M","st_dist_05":"vG1Dzhz8A70KjpnxvZ4SGVd5","st_dist_06":"07GwNw7RTZUXWOZAx60rYf4T","st_dist_07":"gwZ1lNYxgGhC7zSzsjfbhWWi","st_dist_08":"TvOW3z1YJYwcAPU0V5fJO5Zc","st_dist_09":"bSD5RGJ0gD9cwkszsfjUXJVT","st_dist_10":"zjWd1l6GNDTwX03aUMwxfG2T","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LVZzQgSGr2rAHqPGpKkekKUCyBHKMkzQGCZmg9h1Yv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1147,"st_w_id":1,"st_quantity":86,"st_dist_01":"5OPiFcbyut9VCqs9kiDdQeCg","st_dist_02":"SHkR54XCHtk3LhKTqFc9hm9b","st_dist_03":"Muu54Soy4tnKzt0rz5MbJ3uQ","st_dist_04":"GkRKn2zKqyV3U3Zvem0illNE","st_dist_05":"9r0pfV1MoyJQBiTZ2s7FNMqq","st_dist_06":"cb3ZMnzCRiYtOGG9qsSfAoQ9","st_dist_07":"efh6jmg3FS0iXO4TAA2w4rqN","st_dist_08":"Vw71wBQJu8fb7d82URRAO8W5","st_dist_09":"aP5xlouChrzD8CFTDaL8QJDy","st_dist_10":"TL1XyHFFXIhgBaaSnDL1AwxH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lgw8hbbSGoXgloZZ6DfOIsqcuee0PoiUxhig"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1148,"st_w_id":1,"st_quantity":95,"st_dist_01":"7vcJpjyLC6pH6C5YQviMwQiE","st_dist_02":"aohW1vTJwXWvsg0C3N4HKIZ9","st_dist_03":"F46LidZRB45h0i4d8ftRvZL5","st_dist_04":"IevNtzfLzX2Nk7OVhhTVUwkU","st_dist_05":"J5MahK0GKnIgp5Fug4eqDTgX","st_dist_06":"wcjnyiJYYSKnwHeiM9xbycd9","st_dist_07":"4LaURJhzQIP8PA0nsya8Dr5s","st_dist_08":"dn8aQumGsIW8tgyzN3M3xnR7","st_dist_09":"v3SzFmW4tBM0zRFFUhP3P6pE","st_dist_10":"Z7bMbsxOCjXZwYMzcbTnIC3v","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pyNc9wwPYhUPQxMjrKOjQOczol0wKF6irJx7fqMr30"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1149,"st_w_id":1,"st_quantity":71,"st_dist_01":"18Kzqt6ZDXkb4X613uO6QYDl","st_dist_02":"jIsy2pa4McqpdDQblyTlmSIN","st_dist_03":"mVUBUqGZw8b2reUmHGgEpkvN","st_dist_04":"3iGTScYMYpvY7CkbYnQkQnN5","st_dist_05":"LSmbgLgVGtyXEbivtoB7Ox3d","st_dist_06":"0chHJKcPkAqoRjT9McfF4wpP","st_dist_07":"BLtw0nqYulekVZQQ1wBUKBdf","st_dist_08":"2L3JccKdm3KSlMBpCR4PWMP9","st_dist_09":"CsMS1oqnabh2qJQVZuI4eNPS","st_dist_10":"6EmJFDrU8myhIpQ1OPQZKwem","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BlJthVEbI14AQUEvqxTUujWi2OM8S2ioMmABhb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1150,"st_w_id":1,"st_quantity":14,"st_dist_01":"nkm8b7nGdRyVfLEvUjpJeXk7","st_dist_02":"Vv4AqAB237vSgbwbTCDe6qzQ","st_dist_03":"P513Ctt2ryEy1o8uCVIVc5Mx","st_dist_04":"H2xAJ4HpGftYqkPzuLLGG8O5","st_dist_05":"tAa2X2OSI7DyOpw0zajMmajP","st_dist_06":"AjFmClIo57xo8Jco7ZdBhVrv","st_dist_07":"PqwcZ5hb1mOyVtBdxNVn2suy","st_dist_08":"F45KeLGM8W9WMKtNedqif7XD","st_dist_09":"FqcxzGh2gGVpeSAIupqJduwU","st_dist_10":"5m89MCTQFiEMttQmUttmgpNR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ihPkeZq3810EocuzeycbVgScHJeLcFTHtR3AoWChAhyJ8ryu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1151,"st_w_id":1,"st_quantity":97,"st_dist_01":"2CkdhOtu35ME1TVBAHWTnsRy","st_dist_02":"B43Ht8ltexBI3pAUUS8Wpbu0","st_dist_03":"ceUzZXfbeE4gAItWhdimPWwN","st_dist_04":"3XmpD0jZ7pEtdahe2RIlmLTv","st_dist_05":"qaGZ2iABnC2w1vZqXPRQJQtf","st_dist_06":"0hJ2AWGmNhAnwuqPo30Bc4N2","st_dist_07":"BOAxj7KGcRsiih0aDqYZ1Zce","st_dist_08":"vdkoq0aLhEYhrkTfTzjHjMD1","st_dist_09":"x5r4zcMCNnHxL8QoR8kKQQJz","st_dist_10":"mAwm3fNHatZPqXyTYSkIK43Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DzGTScWZGzCudlbOtjgzBm6eipv7DUktoja5vwSkw9v9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1152,"st_w_id":1,"st_quantity":43,"st_dist_01":"7f1umTrs08S4ZaGwSqR8dkAz","st_dist_02":"0xx3ib8HrZDvFNTC72iUEcSy","st_dist_03":"M7LSZ5j7rRWcXu16EkAJBP2j","st_dist_04":"dwDbmn3aWSQTjz0RalT116q8","st_dist_05":"NBluhjVbTqWEHwqVeyonDFdO","st_dist_06":"hFc9LzHwNMVDfrzipq6Yl4Fa","st_dist_07":"ipRBcjb1tNbW15bosAMom98E","st_dist_08":"ashtkGFZcpdfRSOY5OBfIWad","st_dist_09":"zoZN1OfWQQCZXJis5kC7NzdQ","st_dist_10":"4Fkozx4RsBQNwRpzld3dG60G","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"b6yzfNoYpYU8Ql7wzMazaWPJ4e"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1153,"st_w_id":1,"st_quantity":73,"st_dist_01":"eHfhzpyPeks3OTKKmWbKhCeQ","st_dist_02":"RlCzYtKVB84qSfY3euGJ2DyA","st_dist_03":"zPqwhRbzIXFymHAhFVQpoIO5","st_dist_04":"QZpSfCJCkmKRvt6ZEnRRC0sy","st_dist_05":"rTvnOQvNwaDWr3AKpG1kdMhs","st_dist_06":"dSJlF5OQIRhQzIiRxtRWjY0R","st_dist_07":"Sdt2zmJADAjDZ2wzi8mXt0wj","st_dist_08":"Dfm9SKzqTdS6zTLijusIBvDw","st_dist_09":"5C5ETvrlF9D6ggHFdOmiFADL","st_dist_10":"fIU1MHKRPmal9EUuHnnwFUst","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZhEcPDqobevqJ8ATMwgnhxHMGfEPPT0rDbL9sMlZf5K2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1154,"st_w_id":1,"st_quantity":30,"st_dist_01":"ibv9P7O95jZKmic0rGcA5nvG","st_dist_02":"aXkMfLVuCYyPcR1Fhivp5nxq","st_dist_03":"o1gWWsEtrsuT8EHHjIwiFkYT","st_dist_04":"Ou3zElt1e2pjt1RPbEtoMNMy","st_dist_05":"YZZK3xjGIZm9jXxTz3FT8azq","st_dist_06":"jH47bQGndMwm3oRojst8b66s","st_dist_07":"KdfpXpVPmOfKQwum3gZRVSag","st_dist_08":"b6pWkjqZq5hCPZgpLKIeThZh","st_dist_09":"Y2AMEux3NeFWI1nNlPV8qCHu","st_dist_10":"ygAotlLvGCeUmifhay0y6KJE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OtRrOTV5lPRjuysGVrGV0CsGSX0DLQw7YXDgRzBhJcL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1155,"st_w_id":1,"st_quantity":48,"st_dist_01":"NrqAMiXAgPGa6DtmMqybQd7t","st_dist_02":"7LuTWjBWdYO5n18ixcV2Jhac","st_dist_03":"Obebo6mROErFLVe2u6GrndHF","st_dist_04":"dRttdYmf3bErhYBRZeLao5Ma","st_dist_05":"2Noy5dK1KEKiJFUUqtHuxfN1","st_dist_06":"NnuM3rw54kcI6pyB7laTMkFS","st_dist_07":"EnBFbcAldR3EhvM6XhIZEtxG","st_dist_08":"FobsSeDoBO56x8MJfnwdwQo7","st_dist_09":"0Nv0eTbYd9taSJp8QIrjzUCg","st_dist_10":"k2divFSp5GnMmoZ5gJnPXpk0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O52w0Oq1qGjFxuEB8qv6jjQAqZkzFB4ggUmQvE6Gqi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1156,"st_w_id":1,"st_quantity":54,"st_dist_01":"IfVpKtkkziPIpSTyVdsrL0W7","st_dist_02":"yUoCDdPXpI6mwJkziiBGBmK1","st_dist_03":"UIVKXF04DpVGkIIYhQp6DIJS","st_dist_04":"3zXdwtJVWl7xqLM78nIZ0BEt","st_dist_05":"b6rulWiFJhkOAbtxBdEPuekO","st_dist_06":"aZiKQzbNGDkSE6gmBnOmBm4D","st_dist_07":"ICZi7zfJtQNOZ52j94Ejn3MB","st_dist_08":"D6HpdqhX84tMhvAW2HNWWEMw","st_dist_09":"ZcAXCMHDP9GWsPtIUFg5oEQZ","st_dist_10":"nXrdftCFeTEMmfpnSDJAlYBa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GYoI4RWP9O1JfRZbzS9IuXolabQDjqdyO8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1157,"st_w_id":1,"st_quantity":24,"st_dist_01":"iAiDaYMZhz9ydt4peKajnOhe","st_dist_02":"JigMwVAh8i7io0ii0zyR1mlr","st_dist_03":"1Ue0uohM3H8iiW2pmKC9pGDv","st_dist_04":"hEyRuhayhht0xXveE60QejVV","st_dist_05":"L2pxgRlDrf0bv1qApWNYv99v","st_dist_06":"DHZszR7TnAPXdO9PLjxE2CWC","st_dist_07":"OP2VwR7wZ2VVjYaRPd3Wzhzx","st_dist_08":"mWhrKlsTrsjqMm1cDNabXZON","st_dist_09":"SwzmkZukHA783qCxxSeLN95t","st_dist_10":"7w2mEUwXdA8lgPId2tE6IxqQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EOAY38b7j6e0H0k5ITHLO9JzJY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1158,"st_w_id":1,"st_quantity":70,"st_dist_01":"qntkyvzCUqp74n3iDFaRZCwT","st_dist_02":"FvlemUu4T791uYdIE2kDtmVl","st_dist_03":"kWJcFFcyJLSeXrvD0thiYeTq","st_dist_04":"l4cIKnBQsteUa5H0X1M7pbG8","st_dist_05":"X2lfcoTJtEcJZABsL82FpcpI","st_dist_06":"pn9ZuA0GHDqGSop87ZHsn7zj","st_dist_07":"quqltYoj9SHrxRelaNsnHAe5","st_dist_08":"M39df3YL2CuelWObVZROwhnJ","st_dist_09":"v31jsb0EL8K9XKMrFurhLVg7","st_dist_10":"L7H8dH6k9icPxlEMtbq5AeoP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DjLDdgf4jndcxgDlK1p4sStIxb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1159,"st_w_id":1,"st_quantity":42,"st_dist_01":"mgkv4F1FlW4pYau7yoswNsMI","st_dist_02":"AP1EL2q1uDrGi1fq6QaeW8On","st_dist_03":"iskZufV0lDSvvmWxRntLSnXz","st_dist_04":"ITUb9PC3ftqWnosKCVU9d8K3","st_dist_05":"M6Od54HMPt9ihZRHpEi7GYDg","st_dist_06":"96Q4q3T2j22RcZ7MfwJvOcyD","st_dist_07":"POvl5CKntMJpP1B34fII3RMm","st_dist_08":"1mGpYXdX2DhgNdhEfS1r9pbD","st_dist_09":"uMedvtPXJL5oQx0LhKmM5XpB","st_dist_10":"17IktrcLruRDK6ke3oOAx0Yr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tbQ2Ij2kSAf4k4sUuUBB6VdkKMJ72rLQTCGrmcfij6qH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1160,"st_w_id":1,"st_quantity":65,"st_dist_01":"KZWSXGoXGdiNYONGjrWuKj6I","st_dist_02":"IFgGaTkDluJM6Bp0fctNqSs2","st_dist_03":"JuaXldTMPYcGwsoQB6OdLPLZ","st_dist_04":"NkqfoDhzgtqPNkAgo2Nc63lQ","st_dist_05":"Ipt6W0qINHEo8yd4q5ikojs4","st_dist_06":"bbQgWCMyn9K20DKUqM6y7XDz","st_dist_07":"OIOSWx2lXooHsYZ4dX4QcOvx","st_dist_08":"JRu70cKSjB9qnxf6nUtO4XMr","st_dist_09":"q8IyeiRvs8k7tWn9FV6V8muh","st_dist_10":"uLqY31VptE8SoENB5CaOphoQ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8Y4LWvGuDFbhXSft1Jt8fCvMXxj99czigPC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1161,"st_w_id":1,"st_quantity":81,"st_dist_01":"Dg4dNHeb6jRh4nrPHi8aWVSX","st_dist_02":"YqnvReVOuMRnDw4NEnqskJq9","st_dist_03":"XKtQNztODEGkMQKIJXNnwaPS","st_dist_04":"vBgojoK6F8qh7IW3dEsOEc4h","st_dist_05":"gM6iuPboFrmf14NaaPTMbEAp","st_dist_06":"tt8LkohEDfj02DMsWJbXu3ZU","st_dist_07":"yLpv0mINYmxHVpidMzXe7CYV","st_dist_08":"qKW9X6akAfVNoAxYa9QN4cix","st_dist_09":"RbCpnLcgnwu9yy6YoQ6U4b9O","st_dist_10":"pOjYxd27GenbSL21PIGJMVGc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CPwmzbvmwMB0e0DWNFjcF0Tbybey7l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1162,"st_w_id":1,"st_quantity":14,"st_dist_01":"t6FxofNZqo6ErqioE3O1x4MR","st_dist_02":"VEGvRGI3OEBJER9GdrIElD6W","st_dist_03":"DbLpzU7DuhyQiOWZMiK0o1h4","st_dist_04":"Gmh2oM5oZRb1Q3Xi056q9Ozu","st_dist_05":"FEd1dc8FgsLSvtFS7vh6CrO6","st_dist_06":"wjPaLncHR76wyrDQUU9NWlKq","st_dist_07":"jOBZyUahQg2qkDLY2Z0cPcsv","st_dist_08":"jpoC8AqpmFxaM6zKn4xNOMzE","st_dist_09":"Hl7r0H4BQ0K9ejywZglYQsQV","st_dist_10":"rpVlCC7I9N5SlWzSuThWW24p","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zOdQJksEpOiGGznXQ9yyxQxpHf7UXKHjdQU4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1163,"st_w_id":1,"st_quantity":23,"st_dist_01":"C4iZIxYgGCejDPzfy8IaNm8a","st_dist_02":"5xTeOW2eVItYoR7JbWVYdKko","st_dist_03":"adzz7Yq1C8lJTMa8MiIZWt5n","st_dist_04":"DFc5xXPEGegS4D1skpQVkszn","st_dist_05":"gJGeb6Gx9b9YMDrK4jqCdZlM","st_dist_06":"G7O8H4Jc4dRNf0WdeEFu9PgL","st_dist_07":"utcgZzMX2JWSHB9oAC2HshEe","st_dist_08":"boxxv5jaSmXZHyVDP76rXFKs","st_dist_09":"aOiQCbStETBcWMvfydUvQ2xs","st_dist_10":"YKvNvV7IQWpkz6iyfJtaeLAq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cF8nVrDNdOMquXK0xx36fT5fAUk9ea6t1X3L4vtUCcWC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1164,"st_w_id":1,"st_quantity":84,"st_dist_01":"Vn7VslWoMsN4tAyox66U1uq4","st_dist_02":"VL8wPeRbrSLGzjstlzaIRFzi","st_dist_03":"lSkjuJj1tGQYpc6zIbDeP9u8","st_dist_04":"nSgFc3sO9gcx42OjSUQrXePo","st_dist_05":"pQQy3bqviQxBai0vIfaJIGki","st_dist_06":"BDxCcotn14wFKeA49034oFjW","st_dist_07":"agrBwzRDrN8vjUda2u54PWiC","st_dist_08":"bQEnAqFmaCjXUFepoaLWdUi1","st_dist_09":"qD95bEu51pTuEf2nbWVBoIJl","st_dist_10":"exvCsaTDncRDxZY72SpJGDLk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"M29IROuqWy7Ce1kfKw7IGp4qcSa5nIoJ0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1165,"st_w_id":1,"st_quantity":32,"st_dist_01":"TEcvzR6tZ66DF7MYwNqz1yDq","st_dist_02":"3iXRMfbpKqPAdJdUB12lQ8Vc","st_dist_03":"3WLl2IpyRhFR3X24iluWFRw0","st_dist_04":"6vAEBRcMMF2iQV45dUm4ndTp","st_dist_05":"cKWhSbeNqWkTAxmA82JWVuDD","st_dist_06":"aVGzPbTPSc9jhUqhlkUoresD","st_dist_07":"AeL9jkzTOUq4F7mb289jpqiJ","st_dist_08":"82CnfJWJIUrDUveOXp8Q7TPK","st_dist_09":"veypapOpVExustFHaUtsXmKe","st_dist_10":"Azfl5HnTRcUq03dgt0WvTfwy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"T7cPbbUTI3kt5qu8ET9guTD5Lq0vRO9PDgAZc48sfjzotukQ0e"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1166,"st_w_id":1,"st_quantity":38,"st_dist_01":"2C3DUy3slC3M47luwgAd04dI","st_dist_02":"3AS5hsrgToiBBHF22rHW3Ag0","st_dist_03":"mWJD64iTHKZRMxlOBUnFpqQp","st_dist_04":"HMmK5xzeiOiUObqWDTmQz6Hs","st_dist_05":"CNBtmMfJHaECF9StwO14hqQY","st_dist_06":"7Cj1HCY3KpnGvllrHXj71qKg","st_dist_07":"tHyrB0YMO8Z3c1GcxlBGNRaF","st_dist_08":"T6s78QH7c4y8y4GqZh366gP5","st_dist_09":"lby2nTZ0Mv1Zlkl4gm5HAHjT","st_dist_10":"0BFjvYrYfdJqf8wb8kuS9YMe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pB5vXybskNheFJCsWlBzX4HqPBRb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1167,"st_w_id":1,"st_quantity":34,"st_dist_01":"LEK3kTP9NoafDgh1VOwcfnAf","st_dist_02":"GKCVknu5U5qi2HUJG95JPC9I","st_dist_03":"Wf0xGYb1UwKIuaBscrtMW7sY","st_dist_04":"vUf84SFTTYgB4m3WeXjxeoTx","st_dist_05":"ZmZQcGyhaGOK252sJuOzeGje","st_dist_06":"VA5Dem7aJ3KMaDxc2l245e6w","st_dist_07":"b6AKgW1TqDN0HszBtPGrZLEP","st_dist_08":"U63RUw7oDkyPRZnCNtCQwrBd","st_dist_09":"0D2nofUeSFUQJKl2Y9QAjUD3","st_dist_10":"OuK87FUm4yIldBSk69gkdHOH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gZw7QZqTBC3hp0ehQVI2QYOEVb9pfWNXE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1168,"st_w_id":1,"st_quantity":83,"st_dist_01":"0VYjBpmQorq5HGiQovRfj8b9","st_dist_02":"FDlV5MSHYYe6WjfMRWy6acSZ","st_dist_03":"71FgNzQJJJLZIg3WTMNmbSak","st_dist_04":"XI7DgWj5epWThjuWZRdQJyTj","st_dist_05":"MuQflAGBur56409Ya8a8EJvD","st_dist_06":"YFlkjnb4m4oiMQJE802CJItm","st_dist_07":"93vDV7jLQpe0ni0XPZ8i7dA7","st_dist_08":"Nug1Xk7elH7Sh7A4sHTQwsUg","st_dist_09":"DHzh1C12nZAtcfPXVp0HGOTK","st_dist_10":"ZlcyHxShDyxsMl94z3CcMl4R","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kkHQwrLSlU8FsK9ebxKPtjMnrMGOkZBSXfut"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1169,"st_w_id":1,"st_quantity":54,"st_dist_01":"6JoHnR9bqKvh8H3bgNQH9X5u","st_dist_02":"q1g4oxY7aoEOrJ8RjeFLVBI3","st_dist_03":"jnZgUc9Db3iWOWK9phb6P4rI","st_dist_04":"c5ly3yJzwNdSmAHvrOGDlE49","st_dist_05":"fX67CfVttn5evAkmUR0K7xxk","st_dist_06":"y96ChGIVUTBAugo2BecalzX7","st_dist_07":"KfZsT9h8A4LtJ4Z0z03pvUn1","st_dist_08":"OhOvHo4camWGihaCpB2BXt8u","st_dist_09":"ZLy5pxmOJLq34rGRqS85Mh9z","st_dist_10":"B8IteOBVMHypO5n6AfeEx004","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QD3SfROvc382CB1iwDYhNqRoUsVjMq07hu6p16TEK3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1170,"st_w_id":1,"st_quantity":50,"st_dist_01":"PLpULnR8qameT6RiVdosYtaf","st_dist_02":"RAsTmivjkNd1byLMqczGerRA","st_dist_03":"4nLcJMgYh8CzeEKzfJGTofWO","st_dist_04":"KdXYP3AyNIWEj41ZyUwltn6N","st_dist_05":"uzNb3Ui6urNTOPQ7pagQ67TJ","st_dist_06":"cSW1Dts3Vs8gHMSH8I2V30Op","st_dist_07":"eUGdVH9a156xjHD1lunAAGzg","st_dist_08":"4DrmMnNEFvzqNmPbyRw6NWl5","st_dist_09":"plRvHfYqu2UUvbdTicM97zvs","st_dist_10":"BXO4bzaFVCNN0p5rUCnXo0gn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Xu700LrlNTOC78yehJLzuZv17SMoSK0EWaURNrM9WlfIIZwb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1171,"st_w_id":1,"st_quantity":59,"st_dist_01":"2VUGvm4Oi9ZWFLNO9PHPy0Uj","st_dist_02":"fDFP2sWZT6IoAnq6dd9hX8me","st_dist_03":"Va6aJczXw4jMZwyaHaMI6qFR","st_dist_04":"6xDQ71HArdUoCasxGYNOlFOy","st_dist_05":"3u1WcoMY5Lp20IpbtamFEvEx","st_dist_06":"QcjuxThkjGVm9VxiYTIuzyFa","st_dist_07":"7IVYD1wsa70vMIEQ4SN8qa8h","st_dist_08":"wErzbd1s9WmVP9Mt5gcgE0Ng","st_dist_09":"mldKHCj01g3NUYpBBcw9ZGnR","st_dist_10":"VohjmBfrhoznQLn5Hc1PTgsV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cag1diEMmwn6cikOQPq8hQIOsLG9rYd1KDVvcVXtPFUpVbspm9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1172,"st_w_id":1,"st_quantity":31,"st_dist_01":"uKWqXH9KSfcTYRALA7w5ClR4","st_dist_02":"gL5eAcA5KVG68M0SpuPfR9HM","st_dist_03":"v7M1kxEpQL8X8E29KPALQ3c3","st_dist_04":"pFxa5jENAxm2lqiLMAmotxEv","st_dist_05":"Oj3gdPZmYOx14scAi9pljdUF","st_dist_06":"zF9nWYENgrkVRw7pRA5FNrtz","st_dist_07":"s7BpjfhJ3LdEx2V8arSz1DkM","st_dist_08":"IKmQ1z4bQdU85h1H1Xpo18My","st_dist_09":"wRTeklpBJvcNI14gVSq39o4F","st_dist_10":"PhTe2yHaibOv5pfocsCV1SN4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ev3DFjv8530Ta3Fb4dTxexvFCXVItZeVJFby"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1173,"st_w_id":1,"st_quantity":16,"st_dist_01":"73nBXxI8ia8PG6MsSUptpoRF","st_dist_02":"YZqrrs9RYLfJcTz9QuPM2CuS","st_dist_03":"8WZO74gCwAsUi8ztoDGOFkLa","st_dist_04":"Kjo209glgoeIC3tE83WdPQoL","st_dist_05":"XtSG1KWjcChvsV1KoLN7UKrb","st_dist_06":"uDgvvlnhTy1w2mBSIokTxNuR","st_dist_07":"6X8hKJnfSsTKmQ7a01EqmI1m","st_dist_08":"gBtpasoNFH3jFYrCQVvsUdSQ","st_dist_09":"sIzY3Kop219QdZwgJG71KWxM","st_dist_10":"xzTvXwtMQ3AqEuM3KHbroOv4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LOpXYPmSUvew38UdZILSzW5K0sQr8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739244,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1174,"st_w_id":1,"st_quantity":41,"st_dist_01":"tNl2ta6FIfcffUIZsRq8CKv8","st_dist_02":"qXf9SnYZhACKDY911ghRSOqL","st_dist_03":"Zj1bipSYOYQp2gmxRXMxo9ks","st_dist_04":"wgPwGms5J8YcoatQTjwejwWX","st_dist_05":"JWdoeLCFZo35a0MUQTSvxfz2","st_dist_06":"1BhSfceoVehrMTGTrsrgitYB","st_dist_07":"WEe4ilW8WA6inLteScaEL0Ib","st_dist_08":"f5dpupjac31HLsq1qMQTlOnC","st_dist_09":"SpEGyChZqEFZHr7X9c6KpIxv","st_dist_10":"Nic3bKbaAt4t2BK68Cf7ecfI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hOpaQzBBfvCx3eTElt1Sz0QQKMM0JSCqIXaYJJLX4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739244,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1175,"st_w_id":1,"st_quantity":18,"st_dist_01":"kXdG6eJfCqZ1OlYUvdjzI2In","st_dist_02":"GC5g657xkeUarc7Jkub5QGMZ","st_dist_03":"W83HnyRAG4vuR1VqzPXW6gFk","st_dist_04":"0YV8qx9WBi5DFlerjAVs88Ai","st_dist_05":"0usOWn8GaDhCnLhObTB9r9fk","st_dist_06":"Hs5uYTTw8FnAGiA62QHVZOpr","st_dist_07":"tGZGLxjJyxfxgsHDeQtT3KYo","st_dist_08":"DB2gvGFEh1EyLB44TwtdNW8y","st_dist_09":"4e8nxICqiOdn7wocSCLgoYKh","st_dist_10":"yYWsau8XOKpce7upNiCl7IzD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PxdRhCtq6tkotcqYL32E6TgI0Lmoriginalm2kz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1176,"st_w_id":1,"st_quantity":11,"st_dist_01":"PY9q6eq39oFOxcMHUdYEIzJW","st_dist_02":"4jdCcLi7aUMOuK5r3vxVBouP","st_dist_03":"MkQcJj9upjljCroeBNGGyK6s","st_dist_04":"ZUiD9SBpfsjH2HQ6ehXq4vKe","st_dist_05":"Vu8vuUdPKF7m1AXiVKmpBhNs","st_dist_06":"qkYZDQRc88jjkD0LD24j2Jml","st_dist_07":"tUBabSMYQtDJc5Nx8rT0RY2K","st_dist_08":"kHaU46Q5IxMpsSCiaQ5ziDoV","st_dist_09":"I3ByNbcTNaUPiEzxDjHuOzp1","st_dist_10":"gDFsLtaew0JHL4SyPiSWSBm9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ftx4LTXNCDbXlfwxXGF7ILNxJOqKRpaBQBD8Smm8b53Cut"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1177,"st_w_id":1,"st_quantity":83,"st_dist_01":"bv7YyRilBq4QLvg6tEmOokhD","st_dist_02":"w6j2VdVTzKgaqhIXyfxwP43J","st_dist_03":"WI0mCC2XsvTyKuCBVfvNvvhj","st_dist_04":"9ET3OJzIZMDdlje07YOKd7mw","st_dist_05":"qqbgeqmAfx69AOHAdceNkbG6","st_dist_06":"ZnSxToZec4DIIaTBzLxphJX3","st_dist_07":"JndUhoZBp1W35k2a2b1jTFGL","st_dist_08":"efP54JoQwxMP12ielws2VgAw","st_dist_09":"MBLWalxvGaTgesD9O7kg1AOC","st_dist_10":"YeXnIkOfYKKQsy9gdlwCZvN8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nYlqneHI1Yfz5rqQ3aDesozOYOyDpunXtFwpLPjzl8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1178,"st_w_id":1,"st_quantity":66,"st_dist_01":"tlxrLqOXjO6ZCgXWU5vzdnNa","st_dist_02":"p5ZSAwrNlfBdjZkBovMJnijt","st_dist_03":"Nv8GCwZyFvO3AEpKgOiLX98n","st_dist_04":"EzNxWPDlyt9iMjdLo57oe0vp","st_dist_05":"PrJnNLvOEv6uVsJwzaE9K0zV","st_dist_06":"zk9UeCh5XWKkogN7r4C4hvOw","st_dist_07":"zr4f9KIkD1lnvRo0uoQLN8Yd","st_dist_08":"iOulwtxmGZnBcQo2OcI6NNsE","st_dist_09":"OcF2YmG3ngPPGQaI4x1xmgMf","st_dist_10":"5EvLkDbwBOP8CkOoYDpoT1F2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cJjXqBppC9u9Zo64rCf9Vt9wLoriginal7ISIadm69p"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1179,"st_w_id":1,"st_quantity":49,"st_dist_01":"8QAPEK9hzn3WVsRh8bxOT8ZD","st_dist_02":"gT9iQyLPW4VSEpakOfKoeDzk","st_dist_03":"56e8ykFPl208WMZEEYoto6sp","st_dist_04":"Df9Xe9cOEIJK3eEY9PtiIDfx","st_dist_05":"HuJNGSu9uHMHyAjP0lB6hfok","st_dist_06":"U6UYgaJTT5IQ2Fv3LJQNak4G","st_dist_07":"F6Svg3N0vIjpVvQL9gTlMzt3","st_dist_08":"ZTbNrhgTy57RvONXKBalNYHC","st_dist_09":"CEX9o2QTjViaLXku6QblsQDn","st_dist_10":"osNSWS9NLOtJ0J24G45LjZYU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3Pr4z9OWzWMxgiWtGgNM40VteftOFJaNcsKm53XHcQM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1180,"st_w_id":1,"st_quantity":86,"st_dist_01":"4MI8DvQCpS9C4kNuWQVsi5vh","st_dist_02":"EY4u55cjvdmhK6xLJbDDSAKs","st_dist_03":"wT6TeBZk3ZuaVBY6zCES38nw","st_dist_04":"86VjtDtGOoe3Qu5J40aGueEm","st_dist_05":"TjgjF7WDz5Yu6LEZAo72koKy","st_dist_06":"gtY7UGy2KnJsczb29VBgePPE","st_dist_07":"pRS5fNu5mzPZoHvIEkIl0bai","st_dist_08":"8c9GkXx98il1OpyR9fspoGgC","st_dist_09":"PNsyNcn4St5aBZVr0Psz2Tei","st_dist_10":"TODtLmiikitUprLI5iMXKUiH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oenNUY9ew8K7TW6nLFs01mJy53paJpGM5yT3TwnV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1181,"st_w_id":1,"st_quantity":23,"st_dist_01":"nI8sGduqDp5WRgus65iYYyqT","st_dist_02":"nPRR4XTSIGuYkMK9mt0ZetEw","st_dist_03":"ozRdowkBLQTlLc9pqVSAM8aV","st_dist_04":"BrEd7TrVK5jOlDQT5BeSI7gq","st_dist_05":"DJtEzU7pz8HiAVviJIgouLsj","st_dist_06":"h3XVJxmoGcLwyIFe83kJsaua","st_dist_07":"LE2ae2XMuDSTWBRE9klolves","st_dist_08":"VDFI1ghxbACLfBstSe507X3p","st_dist_09":"Dq6MRl2eySovYBY9o8ODLcdA","st_dist_10":"duplOadMt2sCOfTYsXATxkuz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"omBypCwzc3fiDx9VR2HM4pw3YtuHgH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1182,"st_w_id":1,"st_quantity":26,"st_dist_01":"Yc4mqY15gHsaBnbNoP5SSbJn","st_dist_02":"zQEXgQ61rohs5HF9NxYS88bH","st_dist_03":"izi20StUDKNLlBHeUF7WXnwa","st_dist_04":"A7Wgup8pq3hCd03p6ki4q2cN","st_dist_05":"I9W7o8AGKybJKW70ELjXIotn","st_dist_06":"oKUxSlcAfcHQkOszNPFTYNW6","st_dist_07":"9OotX0r2bU6pTsDwXvO3pfbM","st_dist_08":"zcgWgenOrDx5TtJzxAJuqzvF","st_dist_09":"Rli7ZeexeTBugI04DDerAgfT","st_dist_10":"phtdhbNkYuJV44mAoNRMd16K","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CiJDuCnTnh4bCHEzd8reBDfbRr1j2bb8Q4l"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1183,"st_w_id":1,"st_quantity":27,"st_dist_01":"Tfqpl1B6a68AaNBsvuKnCABQ","st_dist_02":"Ecb2pXMiOrcgTcEMcqxpXvD1","st_dist_03":"rMNul1eLP00dif9FEkEc03oc","st_dist_04":"sGu0qgrDZZZaSiZVlIWcWL9b","st_dist_05":"e28yrhsDCnOWdvVLPS4aoa52","st_dist_06":"H8Exz6zOtUtyflu01dBhAvrQ","st_dist_07":"RTKwUiDhwxxUPDDMYuQq0y0s","st_dist_08":"wTLKlgWqu2Jy6MT07397HDjQ","st_dist_09":"9hMHdn436O6lDlIcW1dOEO49","st_dist_10":"cwCOjfcFowOCuPQoyOdy8RJP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ge8ep4TpT7gt0XVh5R8BGv2Um3lupADQv1PZ5nwvWIvDFsSvUv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1184,"st_w_id":1,"st_quantity":84,"st_dist_01":"T9wzzunYFPyLqDw5KHuWyjpm","st_dist_02":"PTItVMMpCfOCSPows4A7o30M","st_dist_03":"VxXekE7j8DjSMV3MGX86rl1B","st_dist_04":"JYa2QwfbKwqK87KRBboMEI8T","st_dist_05":"GXfWr7Z7Y3hh3V4ItFcXYA3V","st_dist_06":"mQP3PBKfMSVmEu74M2gaFiK4","st_dist_07":"D6kgyCbc3qxPglOG98rATEst","st_dist_08":"xVOJJWbDNYmyGgOf6DMKu5RD","st_dist_09":"YBWKzsAsmqYsULLQGIzakwXC","st_dist_10":"hlDnhxnjldmqj0PnqBa2Tftj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oFrlhDB20yqYE147iDzmWHJv2uJZ3BWEthH5jMSoTY5XG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1185,"st_w_id":1,"st_quantity":17,"st_dist_01":"H5JJxEiwMmZoldSmBKfWtxvv","st_dist_02":"ELQ4iQXYlatxaMN2BPAMm0uR","st_dist_03":"l6lwjrC8PQeoHjomyX51WhsH","st_dist_04":"MVaYGB2RPWy2UAcA342Nxxu4","st_dist_05":"zLFmCfm5KPSY4rVItuxilUzU","st_dist_06":"dcRRKbt3M4V1B01mxHFrIEPy","st_dist_07":"COAq3PUT0SjKlj0KbgNKofkH","st_dist_08":"J2PO3VQqlg4KuYiQzbESh1Ab","st_dist_09":"4mZhuxO6Hpq0HrOkGMcO5QRR","st_dist_10":"VQf3JJQZU01VujCjjWAeih5V","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aEpNYT2pSPtNaD28Jjuh1bwDocDgkB2jqIyBoxt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1186,"st_w_id":1,"st_quantity":33,"st_dist_01":"2F5OfRIx7arcvPoj2bYYkPQS","st_dist_02":"RWGjPRW6pU2THu8ocF1avYKQ","st_dist_03":"HOWbJLEJeQ99KUt9rbFeyPMh","st_dist_04":"7JFDc38xaEUzWzjcXY3OHCDE","st_dist_05":"R8Bv1Q4HgWZeSgJbFveF4sHm","st_dist_06":"va5TkpyhL78gpCwlcKE25wQB","st_dist_07":"sfPYMNNaGpC8OTdQfiCIfNJC","st_dist_08":"E7rkRdVUV2p8ozYZUhHcj7EJ","st_dist_09":"mMvnzdxMLxWdYDqLTpY3PJCm","st_dist_10":"yAMAIWdxgBMTdjb1jcKkiGAA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Kc2xnCqsveEEfoOtNBK5f5QUsaL81olq3V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1187,"st_w_id":1,"st_quantity":33,"st_dist_01":"XifkrLIuGvGCMHDF2yPxRV0I","st_dist_02":"LTK4RsyVJDD8ZhcmHrElCrg6","st_dist_03":"BjoFeyrhy17v1P3uBX80ftOy","st_dist_04":"TTaXNNN74Gi7au70k0riDOLx","st_dist_05":"wHMe4BX6fRYKMLjZ3UR4Nm19","st_dist_06":"PgSJ1tTPHJaxY7rAbgnOIqXh","st_dist_07":"KW9lxEkuzPVsmMYnAfOmTjtJ","st_dist_08":"nzbCfGfZSw47IlaYtBkLgh8A","st_dist_09":"FnJ1laUdLPJpLg9vTgwTq46j","st_dist_10":"ubeAHCVPeKVDUShMH3h8kq6z","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"thmPitpgInHzQrjupjE4x7wrV2xFKt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1188,"st_w_id":1,"st_quantity":95,"st_dist_01":"HLrF9jJLNCtVxQJ5uQ0mF4yu","st_dist_02":"xphAfmxQVvGlJa1VwCWSMTCK","st_dist_03":"QmhocYO1tChVG0VCEvoiHwz5","st_dist_04":"kFHlHq5siiVsXhKPbfveKmpi","st_dist_05":"8QUoTjZTqOegSvBSYxjYT2R4","st_dist_06":"9Otyxx5AOSnxLYquczzevIAh","st_dist_07":"eQG0scYdcuc1CB5tlXIi8LnW","st_dist_08":"adMjv8LVVx3t50IltpNLKndK","st_dist_09":"7WOkVxeSvDzo9yHgZqasFSo6","st_dist_10":"eFGqjdfKcsFxlCtwn8gnX4Nu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QVvkxcFDoJCNmtJsUqtSLX2YQ6eZFG8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1189,"st_w_id":1,"st_quantity":62,"st_dist_01":"P97IWIcbt4c9q9tDLfamRmq4","st_dist_02":"p0rSsiY7sehStwnIBgKuePJW","st_dist_03":"SUxlhQouXDEl3fNFdwAE3LwL","st_dist_04":"vAC81lIfHEIpVWhCWRxFXQrc","st_dist_05":"h11QgN4VaXgn8L7LsEQAXYM0","st_dist_06":"JFDGLox3eM5FDI79zpyTclTh","st_dist_07":"alOJSj3kqIcUMa9Vq6NdmgTG","st_dist_08":"nQLIcEqJcVKWTYmaCNWFqYUR","st_dist_09":"CgTSueLW64hevqWneY4hYAm4","st_dist_10":"Uv8b3YnrJkAjk51h133S2aD7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FXBmRcgfjE90ZhEXWv97gT8Jxa19Poc5dsoA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1190,"st_w_id":1,"st_quantity":70,"st_dist_01":"a7oYZmLbVbosJTibNDXf2Z4r","st_dist_02":"vj1SNyNu9nwjmNsntcrQf8Wd","st_dist_03":"9EEdgxW1nrzTOqFSYsbrpGeA","st_dist_04":"gjieqH8rdOtWmZbsP8Pn35nL","st_dist_05":"RRUI6zJbqbSTTZIX0hJGjJN0","st_dist_06":"9gtneUnM3RgwaKoQbFaxlzXh","st_dist_07":"9FNKyqlPqNC6eVa4XIxJbGg4","st_dist_08":"K286IzDCwUMu1m87xjdgG5iT","st_dist_09":"VifkZBRGy0UgaGogUAtRlJoz","st_dist_10":"18oN9683CUhhFsUJ6scHV8fq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JPG1DwdCEmvAVOILizX7yTJnAdMRTJI2FS2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1191,"st_w_id":1,"st_quantity":92,"st_dist_01":"YMBQ9OVmESTDcdsOwJ7RJlU1","st_dist_02":"1Cgz6HP2OJnXdVzl4EBMQQ12","st_dist_03":"nUcpgMU6u5IHSnXxVSwMvkUu","st_dist_04":"jyXGwlHkGr1ZBe1YaGeGWW76","st_dist_05":"SA0Boj3ZMB4HsgABahI42jPo","st_dist_06":"KnoOQFnb5RCbwLOuI2SfSlWQ","st_dist_07":"SCIgI6ZHgJwpiOkYfwevy3Di","st_dist_08":"di9nQMZtWijsJLw7jMAxapew","st_dist_09":"5ecO2R8XrumigE18ePiSDzKx","st_dist_10":"hRLB153GxatBSyOk3JUxbblC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rCt3nPVmsxvEBfSVn4Pi7NsPb888HmCbjAxY8Knan"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1192,"st_w_id":1,"st_quantity":78,"st_dist_01":"3aITP33LxF1cZQyX8ZxttOnR","st_dist_02":"HHiYoarrAc7Sjl3YCVNiw7Fk","st_dist_03":"p4OxlCIpjFh3Yl4Zq7XISTA5","st_dist_04":"nj7omrnFsIgRFEhSfc49YiV2","st_dist_05":"V65OIR39eMnEf7c9RvnjWeTf","st_dist_06":"5HJ9qW7H9WZJp7qqActI6GCj","st_dist_07":"slUzrNXopFcaY1cqodSRxCjf","st_dist_08":"sB8KH6OTuLj1WhP2FNhyZ5Xz","st_dist_09":"0DQXSBwcHK3aIv2lAcmIFTxl","st_dist_10":"eHdkD15mBpCpxMbYNOkuce9n","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eTbEyV19PR6Dxq3f1V6Hv1ilae3rypSNmjCYJvL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1193,"st_w_id":1,"st_quantity":86,"st_dist_01":"Yb4pEq0f8sQmBpvLiNIikdHd","st_dist_02":"OVaTR1yt9UNiWSrBvayJ00c0","st_dist_03":"Dkg3eYSKm7A79Vw3YVqh8ZBB","st_dist_04":"pVlW2cotgeOl5aiFVEG06f8L","st_dist_05":"PsDjp7FZyIJjmlQGH4IIzKJ1","st_dist_06":"6nn73xaMJm1Kf5BCeOU71kAB","st_dist_07":"8jRE4UBxggP3AbEOBplq3w0g","st_dist_08":"QGZ02KQRFaJjvXDGlqYJz5RM","st_dist_09":"OMJy8hHiPsbysg6uFZiLHSVQ","st_dist_10":"OKrse2TUaXqXAsWAnw3Jxkdo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8IWCR9GbELve7IIjoriginalKD6fE5Vhfq2U2WwNmupuc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1194,"st_w_id":1,"st_quantity":37,"st_dist_01":"CMPj7xYG6l6VEjDoQKKlLo9V","st_dist_02":"l9rCeLV22Ra1VLGLV135dmqJ","st_dist_03":"EW2c3J6pGK220yhoc4wPh8k9","st_dist_04":"CcyXrUirUEWIkEpWggeItrnz","st_dist_05":"LW5sXuVNIW1UUI3lKMmmlAOf","st_dist_06":"vvnm3ZtJjVOt2uMi108bXnw4","st_dist_07":"x0DXkRxSmlRLQv7rrOrGpNbu","st_dist_08":"wlCsjxqWSSXYX0RonLbmrMdz","st_dist_09":"xIpZVAa6NihszuLHVAJpah8a","st_dist_10":"YK3EXtDEQv5XqlNyVvWKjqum","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SYfi4tz7JpC5hZe4xzDuGBx6a3QCURf6KCf5HxCmL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1195,"st_w_id":1,"st_quantity":43,"st_dist_01":"yVZ6gZeEpnv7SJh28wHJq1vd","st_dist_02":"QawSQwvUnOLk2w7hRIiHlaLN","st_dist_03":"cNndaWY6kCJJBfMJHa78qRSB","st_dist_04":"mAwBGehzwcYrFBau5Y4Itj1Z","st_dist_05":"SV9v6FlhU7xILkjhjd6WdjrW","st_dist_06":"pmS9Gr7CbSQflJ5EsLmyEniB","st_dist_07":"vYqw23AtWUuaqC1UrkWQpgh3","st_dist_08":"Uexi72AUygrtCsphe478YTwv","st_dist_09":"r6NqApnczKDa9VrIPEnHQvv8","st_dist_10":"t2wlwfxKASQmELhQjSim6Wq8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ldeyxnz7fmWwfpoK52L7SixA6vO1tucUByjeNktD4Jp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1196,"st_w_id":1,"st_quantity":12,"st_dist_01":"bR7qjohqa68P5OhrPosFKHhQ","st_dist_02":"gwoS2VvGJ7KUwqMMLebCwldu","st_dist_03":"X1dneYXoWSXLfBrhzaU5O5ns","st_dist_04":"xw2pgpYndKyWIaA2tywjjvRQ","st_dist_05":"gEWTNz4EHRkf5hXqTMpYTRtX","st_dist_06":"XurJcYycxbsgRZd511oEvxJ3","st_dist_07":"jd4hSnn76Fzj7LsCZVaErqoT","st_dist_08":"RJqxsrK9eijqG9bc7X47wjpn","st_dist_09":"Tw2bkJbKtRgd7oIJcsx9w5xl","st_dist_10":"6kUlZWaCeR9YUmVhT4kvF8Rs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2Mtuwxuq3RuIGjSCw6CzyXXCzRTB0P0w6hhsbU3sHi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1197,"st_w_id":1,"st_quantity":41,"st_dist_01":"R6VfjKTYRPURt8dlQ1kZGMCB","st_dist_02":"5veWDEtzazGwQE1NWtyHggV1","st_dist_03":"snbaRfH9mRZg5YH2B2CAibKr","st_dist_04":"4S1SxXu9Rbt649GCK092dhMR","st_dist_05":"cBQh2T95lTsmRexHuKwYR2Mo","st_dist_06":"0cwru8LFcHFYa6iRyu7xpKxE","st_dist_07":"mzLIOI9NFJGJ8GOrDr0CDZIk","st_dist_08":"fZi8nNQwCTWgiBtMUAsiMBJZ","st_dist_09":"kTSaJE415HaaQOeRlxrZdfJx","st_dist_10":"tXVm2XTVUYPRylW6MD7OEY3b","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"720cpEuPivO4NdNOakItebbB9MlPzuikcza8jH0A2U1F"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1198,"st_w_id":1,"st_quantity":98,"st_dist_01":"Uajz3MSQWeGh9ZZrvVZqzKcf","st_dist_02":"i9CsysYoey7aWseiHCBx0vAE","st_dist_03":"vMMKgwYMIRwmce91SuJiOhm7","st_dist_04":"xgEKF27sMAotIYzaauLv2wak","st_dist_05":"Ov1QRPxH5UYaFDuT8kl6ULZQ","st_dist_06":"V4PBl5HPmzK0In3BwzohNjBp","st_dist_07":"q1N7d7Lu13i835bHK5s668U5","st_dist_08":"y98xScanjChZg22qRQrJ3UCb","st_dist_09":"gApWXaDb1q6m8u5JvaXoCTj3","st_dist_10":"ivEf35G6hOToPC8bRTwcgVMR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"12qIOy3Hmny11Bv9IZh5Xe4LQMeC7uqS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1199,"st_w_id":1,"st_quantity":33,"st_dist_01":"8T358IgpQIfMt5XiTGzEHAH3","st_dist_02":"WzhqPqqNMD5SgjlXs7YkbsDJ","st_dist_03":"jooJiTCXsuVZ7WUsGCBIxekp","st_dist_04":"6Xl6odUtprDDvUJYXoGZRslq","st_dist_05":"awpduyI19g6hOJhGYytDalIx","st_dist_06":"o4Tb5kAADUUvaDY2JQRz3Hth","st_dist_07":"fp7naoGTkU4Dm9jf056ZQstC","st_dist_08":"Aqck6psVVxSO18TbewDXam6G","st_dist_09":"TLCmpkBXg83AKAm40BkG6dHc","st_dist_10":"l6YoTwxW1nIwS4gxPZMPDJLp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"omhYLsvmTPFedR68dtO1oVDISo1EiymmW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1200,"st_w_id":1,"st_quantity":19,"st_dist_01":"eWynWAti9JpXd9cRPPENDlGQ","st_dist_02":"579w7CRy9yOclob0C9jpujtu","st_dist_03":"b0y7ay1ABxzycj0x0XS87ALG","st_dist_04":"rSueDSNyaUhT6GcPHC4Gz5HL","st_dist_05":"tXAFTfqERs5Lf4Y8Q082wvs4","st_dist_06":"vUt73XiPyFCYR0Y6dtcQLOiy","st_dist_07":"GoHo256EaY530nuZGRIdx2to","st_dist_08":"i2xfEmsgIA3pDEEESZGWIHpf","st_dist_09":"SjpQVH7kzm3liDioO7yf0fKO","st_dist_10":"KaDCzcvR2jpx3CRHr4CHUGHj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PaKmqoe18gywjVqxdClVNmxJoMS66P49PAVkc1WDYt0oVMsC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1201,"st_w_id":1,"st_quantity":19,"st_dist_01":"ds65QJb85dSXaHYYOh7zastD","st_dist_02":"Css3oCcnuM7bkXWLl61lLhz5","st_dist_03":"sUxbZifLtTpUHgQiYiDT8TVW","st_dist_04":"iVDTUGFbHsVYyScYY1aYZXpD","st_dist_05":"zQ1W9pP1B4bPNBFghOFWy1O1","st_dist_06":"3lcWKvkUrg685hHpHhBkpSdg","st_dist_07":"hBFX74lmN9ZDiVJEy8ScPUrj","st_dist_08":"Dox7eAhy7xm7fkUR0Ojnp9w6","st_dist_09":"orYJfhyPpTBwLAVwaYgPWIYo","st_dist_10":"DdNSxT1r51XfqMpI64IUomxG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Kelnw4RcZ6ZD4XQI0Rd47x2WJZ2S4ADaKk2zptt9vwE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1202,"st_w_id":1,"st_quantity":12,"st_dist_01":"sMt8hIrkd6JrtIRPRF3UJ2Sq","st_dist_02":"t66HjhoQKoBjoqVjpyemIHDC","st_dist_03":"uS6uOHRm2SQYpYRIbpyapybS","st_dist_04":"s88VW6eJPmvfpLHZwky720iK","st_dist_05":"U7uZD6SH9F28aD5ULKUU3ntj","st_dist_06":"p1xOJ3LKKMwjgUUEIn3digWA","st_dist_07":"9iQ42VfTuGRsRdR1vBtXOJEL","st_dist_08":"d7OcXhztR4c0MkdFA5P868bB","st_dist_09":"qjl4BwwWGUjQ2taEhJIErGiY","st_dist_10":"TTeGiSADhPvYWDOP9tzMklLS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eIfovVvtQeNIZu0Yovl7UhQJp87"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1203,"st_w_id":1,"st_quantity":36,"st_dist_01":"eWG2m0gwSDTMn9SnKLVRrPTG","st_dist_02":"9E44pfinNR0z102IPJloct1m","st_dist_03":"3a7kETpxA5GJiAfGWP1esLfH","st_dist_04":"UYkJ2e7FIvVD572jTAitVhP1","st_dist_05":"9MeglhgXEiH3V4azfsQRDCXR","st_dist_06":"x0U7WKHmHUv09nlQetdBpdld","st_dist_07":"RYPwXHAhBCjoNmQvDqD0RqkR","st_dist_08":"sMfpbgsIlT5qiec9USGwO9nm","st_dist_09":"Q1vG21A4qOWmMKnMU7JiISpy","st_dist_10":"o95jnpnULIFT1gWLNM7RHOyP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gNH1xKPAfjI9OfA8ylBrxkrLOiKE9KcW6lBmzyAIRj4cKIOxc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1204,"st_w_id":1,"st_quantity":37,"st_dist_01":"ZbEA7B0bOcgg9D1jFKy2dPWI","st_dist_02":"n6yFoImAMlKIIciQHXoWVT7B","st_dist_03":"r90zLW089Fcc6qa4Nac88DT2","st_dist_04":"H5aVjCazLpA9ILDkA9BISKdv","st_dist_05":"XdO64xxOYcpmEVPiHDcV2hsT","st_dist_06":"Yfzsfheyl3pBgSgNhM3RVlCV","st_dist_07":"6Jpegj3Hb21jjNm50T3KnonP","st_dist_08":"WBJGAjMIHTSkKDZxdHWo0HKI","st_dist_09":"Am8oTwERQEMGb1yBNywdblot","st_dist_10":"7uSfBK75qgqQhx1iWx7meZok","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JzO7ryUXdUrRHqRs4xHChyvp4Lz4ISg9dwzU3OxI9oo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1205,"st_w_id":1,"st_quantity":92,"st_dist_01":"pUu0piizHDGTNdK5lQnyekuA","st_dist_02":"i8S0VpxU8D87LL4iZWYgpRuE","st_dist_03":"7bYoQBItd0CauJMWkmvBDlEs","st_dist_04":"qM8aOkxHINr02g1sHiSLBEMa","st_dist_05":"I8H0fMKZqu30AOIKK07cgrbj","st_dist_06":"2g3oaxODaLJFIkCHRrUpOFrq","st_dist_07":"8qZc881TXsavlyBBq904NWPl","st_dist_08":"6trSS7HFDu3HFgkeIJYuSNVP","st_dist_09":"gU5gHqua12O0crmhDh7KtIqa","st_dist_10":"6KjJGkno3J6AD65OkpX3bFL3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XVPtE5DMBoIOv3WIw0GwmjJ5EWQXibTdUHwj0ViW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1206,"st_w_id":1,"st_quantity":19,"st_dist_01":"VHRrKr6cpwBtw4ayP6aJE5S2","st_dist_02":"CaF2qQeK9iRiXCRCcFUdZtf7","st_dist_03":"co3tRujjg6q5UKlkNuIkLOg3","st_dist_04":"S6WsI3cPKSFsPbF1e33ORUSD","st_dist_05":"qa1CPkKZKgKx77qO5fH0HEei","st_dist_06":"SPgGkskgUcRN666edfHXwiZn","st_dist_07":"jA9eIhnCHds3Za6NyzG9wj5R","st_dist_08":"Iy5ygyfnYv214PH9dqPp76BY","st_dist_09":"PoMjfR7iPejY3th2Z4GSZvy7","st_dist_10":"N15S2ulX6c5vRi3KOVC7bVI1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uqN4QaYYa43vXi2XayCkatncJJSJAS5hQAX24ztzmGU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1207,"st_w_id":1,"st_quantity":32,"st_dist_01":"8nJdRhZ8TAva06vWnO9L1wpg","st_dist_02":"q9WKRqkMGJOb2JH4jOXR3KAa","st_dist_03":"EVHBQBHs3HJ9eicsACkg6Jam","st_dist_04":"cEkNiN6r6TxrCq0usq5HLAHg","st_dist_05":"KY9llc9AGYzfLvuSfmqRpUVh","st_dist_06":"GK0C8hN96JJ2qUCLM6ffhYZW","st_dist_07":"kLog8cRQ2F8HRYFj7PhfK7A5","st_dist_08":"PBoxLdUsojSl3YuXZLzAtIfH","st_dist_09":"xCDukR0H1EsQR1M4F9o1jDyc","st_dist_10":"uN03IWsAigHd6x7nmbWniHsE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"e1u3USHMj8lCemfKK1E9fE9lHjB5RgtT7gAuap"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1208,"st_w_id":1,"st_quantity":10,"st_dist_01":"Xr7dJLvGl3H3ArlzsEPHjzd3","st_dist_02":"FgBLU3UAmUm6pjGItVCVdYyR","st_dist_03":"nsY0BoWL6s8NR4WZsV44wNrf","st_dist_04":"VT455XUXRrzioQO1D0TPz4Wk","st_dist_05":"7XbJS8UQXhX08drxvtvLc0Rw","st_dist_06":"1wGeZ8BJuETDujcgVKONEbiW","st_dist_07":"6VaZUJrG5lV5ythptW66CK5t","st_dist_08":"g7cX6itd2jAOX6TXNWjaksqJ","st_dist_09":"5lXjDQgYrM8tuhtE2zVLgyjp","st_dist_10":"dPDFH8P4MkjFzlIMeBUdMyiP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3UD4sx1DcDTJCiDRfUtgaKmhstDDCjpWgw7soktTUWYY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1209,"st_w_id":1,"st_quantity":34,"st_dist_01":"694gYUFjCt1WMMcxeavij3Jr","st_dist_02":"FXPQ9jW2jXkwK2EZ2tRA8zGY","st_dist_03":"LWgVg41cIM4oZYH0dg34mm0h","st_dist_04":"w9RWRk8Fd4Lxn3m5tpvCDp9l","st_dist_05":"lTLQ8DlTorhs4ilmx3SMQeoI","st_dist_06":"wTifVPhTuTUWqNhnoeGg0wVh","st_dist_07":"Cbl5C3XxVZn48NzJNYgVOfc0","st_dist_08":"ZzTUaBASdmgLnAzeR0HJM2Uw","st_dist_09":"WUiizWlJvKojtgYxKgGi5gd9","st_dist_10":"vI3MvsHl4waA38irdZqddT7W","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tZVlJGViZim0a5it9nNnrayt6doB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1210,"st_w_id":1,"st_quantity":55,"st_dist_01":"av3faE4wMNWONGJIZpKcIWo5","st_dist_02":"G2Sdb4RItQXzEkpe1Z5Smlef","st_dist_03":"V12DkZkZWxDOvTWRFK11HuPc","st_dist_04":"JXiTWPkCgwvq290kFoTSjfP3","st_dist_05":"MG7Zpcc6fj7L1XMM0Eyix3qs","st_dist_06":"ynpjPncBDtIpaQRmmQCFzsCJ","st_dist_07":"po11V5Vgt2Yv94V6pzg0nuVe","st_dist_08":"7FnS3bdKmD4Lge1ZYfBUYn6w","st_dist_09":"SEmvxHBHDk8s9HGgs2KYUjHd","st_dist_10":"Srdd6j833kkp6KggOhQdMpyk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"05BHna3s6Lxxvv2aysnUnOliD62Us2wId0dccNAH3S9SlLj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1211,"st_w_id":1,"st_quantity":23,"st_dist_01":"UykyMpLMR5pmU8XbWhG2di1q","st_dist_02":"oMpZST77T6SCdAFWQ3xe0OHL","st_dist_03":"RfICukFM46TexHLpZGH503hA","st_dist_04":"VcqjcucuS3QdfqgirCJOdAps","st_dist_05":"TwDEMfer6lzT1Rqv8eI7RKYv","st_dist_06":"YVqV5OdTQffpoLPEFrJC7096","st_dist_07":"I1KlgP8crXpyzhQvhyJ2bUbO","st_dist_08":"PMVAIJvx6MonISb9hyg0h5cL","st_dist_09":"972wwU1MBMOrsJUni6LRtVv5","st_dist_10":"zT9rwTAvMiwDH7uXd49spDbl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"52fX0z8gMLTKHjvJPLUDMD9ctU08NjFukPuAQ3a1YKJr6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1212,"st_w_id":1,"st_quantity":81,"st_dist_01":"d4tQpT7ken8UF1S6s7FZBhOr","st_dist_02":"z4U98sYPGehVj1aSkoaHdVb6","st_dist_03":"1Tbo2zo9kYJqUF4y0waPAJc0","st_dist_04":"2l53u1oD5JNfLvf0zmkCFZRG","st_dist_05":"ZSkg4euhCcLpmuy7VQyjIzgl","st_dist_06":"L4P0C0mkztHzJnplY7kdE7lm","st_dist_07":"7DVYFAANmWWnMnr4DSqiqecF","st_dist_08":"9nfF1TrZelQ6w3bKwFePdSw8","st_dist_09":"TmJKyJePyEM1fzDilagERNqj","st_dist_10":"k64Ty7G8zUkHTMrJ5OWlUxjt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8ZVMM8HdrHMZNPRQXh9TKw8nOq9Ynn23ji6xyYo8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1213,"st_w_id":1,"st_quantity":88,"st_dist_01":"08bwASg5PgjyezYDwsYwKLuy","st_dist_02":"GBZ5D8qUVBUAoB7G3rvm7Td3","st_dist_03":"kgFne5LjnQPRS25XTJFUzBDZ","st_dist_04":"jEAbQeelyxUdobEkUopO2YdT","st_dist_05":"IFTxJ4G8c1gSEfBXFJqGSDFh","st_dist_06":"00w3XEzTwbQuCEvSXbCj1cGJ","st_dist_07":"9ML3DrP5lP5DD12vUEVNSp2x","st_dist_08":"H8K0ZHbGcckcLweE7UKzckHY","st_dist_09":"iSw19AiwPnfOaQDX9L5Y6OSv","st_dist_10":"a3AIOeFd1T4lwHTyw1WnhiTC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"d3HQabwC9G2TLVGFB6XfTCxcTwpswLr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1214,"st_w_id":1,"st_quantity":59,"st_dist_01":"70YFg8Z0bm3igbrB4t9ppyYY","st_dist_02":"nuZ775LVCcseizuPGZFfaZWO","st_dist_03":"tZiOsLQpwlUKJkvDE7RC7YAk","st_dist_04":"pesMKfTxG2weUT2EF7Saftgg","st_dist_05":"C9CGFfGcLu7AFeBpAr9URgAe","st_dist_06":"kWYp47EAEq9zuBiNPkMcBTVv","st_dist_07":"a9O6aYS5jbSwwl6qosHUsHnr","st_dist_08":"D4RCZWnFOF3N8ewcso9H4YMv","st_dist_09":"6CzdbMNYM9E9Xya4mn0wvYKa","st_dist_10":"fJlm1jFwHo2ACt1M6LQFT2tA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jZwTAEj91IJXHw7LSf2xc7L0RFp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1215,"st_w_id":1,"st_quantity":65,"st_dist_01":"9RhyFKOFXzWfzPrjj1PPsy6g","st_dist_02":"VpL21FKFCE9dPSmGnF3pMfCK","st_dist_03":"9T5GhtcVRV7Yn9GOZu1kkj6o","st_dist_04":"OVD2k7kSqDfQACwLNszoN1BO","st_dist_05":"WSmYhO41wU9rdEPQx37gyh5f","st_dist_06":"Iz1UzwnzmXvnSvM4DkacE1rY","st_dist_07":"WR0wR37hKLryt2jxEYOpOdJN","st_dist_08":"Izw04gqWUNKi5jAwVORF5pjG","st_dist_09":"ynOsPYLvCOv3butiXyoIM3wR","st_dist_10":"egvRYNm8BCWE5Iae1nqSmq0o","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Gf5NezPAqMsa7PyKqKpXSwknS7xxqx1HCm3z4gzqDNE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1216,"st_w_id":1,"st_quantity":27,"st_dist_01":"yP7XVlzYbEdNPij5dFu54FyZ","st_dist_02":"J8rp2y8MqYPcBzJEch32UBhQ","st_dist_03":"yCSszjrPWrsigzSSxxQYybzz","st_dist_04":"V89vcOzJCDYP4bVaklKYsM0j","st_dist_05":"xlQDRx7fUXrIiGSLJeHyFZRh","st_dist_06":"aG85TK696Dn3GarYyHYLhgMe","st_dist_07":"yG32CApcggNGpG9q0HbtzTKp","st_dist_08":"tLeFN5kcEmwAE1l8X1xorRG9","st_dist_09":"g61PnzX2SOAGieNK5FJcIbQP","st_dist_10":"qLCJOZn6xMeMjriEpEFc37Il","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xU0JQ98VGvkR448QOgoGTeL4Oy3wOipOPzAc7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1217,"st_w_id":1,"st_quantity":47,"st_dist_01":"PY2nP9cW8o3O6fDRSZj8yWDZ","st_dist_02":"TtaIpTvixqklkp2sEs8lPYjn","st_dist_03":"6MaCjYveOHy9H9q3cCvZjoHK","st_dist_04":"TTehbXcl0gCGIPGNSbJMaT9L","st_dist_05":"GCjr5XfoFoMq6K7rd53axS6C","st_dist_06":"9zJK4yp9QLU0snouy19HgSHD","st_dist_07":"dupqbCJi5ZQsbBNBh2Kuep4g","st_dist_08":"z1xqBacZV1E4JdfYTbXpnSjr","st_dist_09":"KsLv2Y0LtweD3JTaIJZOSGAU","st_dist_10":"3mKBrbgkMjXZDw6kXpkTn8CI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"originalEpQzwh2Mhg15iHVnRnT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1218,"st_w_id":1,"st_quantity":14,"st_dist_01":"OVfqQ3Wy3vEvGqnzTirggBEZ","st_dist_02":"mpYyI6ySoPDi09b1lkPzRQNr","st_dist_03":"405nXPntyGYqs0beROalYdq0","st_dist_04":"60ywyply5fPAIbUEEzvcQhmF","st_dist_05":"Uf8iwJpACDlMs6eDZxZ0JU86","st_dist_06":"BaaSj25vJXVjECmyro4a21SE","st_dist_07":"wRtjCUDJau7u2FZQSCHkAhVp","st_dist_08":"NJdO7s80Wn7AHLC9S4s32Igm","st_dist_09":"GiObj5sfQ94zvk6403O7wPFy","st_dist_10":"GaG7XxRKau7MaZxe9Kb7smd9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2EnV5hz9E2rQjGV9F2ruUUarA8P6Db4jpXygT0xhP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1219,"st_w_id":1,"st_quantity":46,"st_dist_01":"mULUZJiSDbfn6ufhbXlsecFn","st_dist_02":"v11g24Skw1ErozakwUQ5Y6yj","st_dist_03":"bJa4tpa0EJBevmwGGsZHjqEx","st_dist_04":"QwurRsmrdtlKNwc3bvtOP8xX","st_dist_05":"TykqvmXr5b10SAW0xnAoI2w7","st_dist_06":"gs1XsROpU6n80XwfrL36qOGs","st_dist_07":"DMqxjoqEVBVY9G357rrQJiBx","st_dist_08":"6RxKc2AzDzuk0to4dSaJOusj","st_dist_09":"8Ib4fSYnRQYxgvrGJ1T4lZsS","st_dist_10":"gYypq9ki6dazvpzZPxU92D7d","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"e6PAuWyNjI4qIwDgpOhcHye5xAyJG8J"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1220,"st_w_id":1,"st_quantity":51,"st_dist_01":"a1RsXvQDvQiFQcLzfcS9Ftkj","st_dist_02":"NAGIORDDGd7M9muGokecIvd7","st_dist_03":"M5OfAxgZTQWvY5yETyUlCPln","st_dist_04":"anmmbaHVU8E9toKDo1wH6FfM","st_dist_05":"4M1ILTk6wKUvanTEhaxoqdKM","st_dist_06":"5qLxCrMgngE0ZXeiOOzE48eN","st_dist_07":"ZQHs47gUsLX6R9d2mUopvmzL","st_dist_08":"Z3twXFpkff6QoSoraNT9lVoL","st_dist_09":"774vIwhUlR3MvHdryipppf2X","st_dist_10":"zk5UOC1XadIRzDVzrdF2BtY3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uPHRVzyiomshl9wR4UGhMoMlyViVKLlSnLCBdpkX1Un"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1221,"st_w_id":1,"st_quantity":62,"st_dist_01":"Qu91HT3C6PyVwZUVVLbTs6Ri","st_dist_02":"PxaZ7WLsQ3vW3aqT0RsHFcn6","st_dist_03":"diN2wfSB113lPwn6yYXbDeGG","st_dist_04":"1vXMv7deSTDPMMfsyRLRGFI0","st_dist_05":"9SMy5vPWEYCKH5euKDX90ONF","st_dist_06":"mazvYgsUdkvQeKoyhXswYZh8","st_dist_07":"QLpJwhWceN8h71gyfqmNWiM1","st_dist_08":"C1z8nJoEN2yR4ngr6D9tYcP7","st_dist_09":"xk2enaOlPpjWFSC0OgGZGHiZ","st_dist_10":"ALroyo2EKF3ukg3F1fHbVdai","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TNOqsWCJWhb8BYGcWYBxMBX50cDM0khF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1222,"st_w_id":1,"st_quantity":33,"st_dist_01":"Z8w3LyGsrtDSzftafgpn3n7p","st_dist_02":"HLXjNDMDQnsGmh4MhhCj4gcg","st_dist_03":"3lc3faIETyVFaqkBZPuNC6vh","st_dist_04":"foll20rzuZU1VguLNoB8lQNL","st_dist_05":"JR3ayriZoLBv1NYOYtCCwEvJ","st_dist_06":"aErIu36MjiqRYtz7qxV87n8K","st_dist_07":"0G7UfCGLSeConMzozPA7YR82","st_dist_08":"UuusvpFlY3LQptCbUQxPieDY","st_dist_09":"zpVOdTyFHkq4DpZVVnQQw7pi","st_dist_10":"4D8q3bEyiyILgcXlV4mgCOaA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3qvoicRfRB9APIchU4fsVacnjLvHDqtvY2DPGpT8VszR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1223,"st_w_id":1,"st_quantity":52,"st_dist_01":"nEAHkDi9SuZHUq88tZtFFxU6","st_dist_02":"yhjULNrcOyZ951Kfw4nnCZyx","st_dist_03":"QQqCiakkxRqbX7tiOLAUjMU3","st_dist_04":"hwRuS1DozPj0XZECCOJMMJQM","st_dist_05":"6q99FxTSj8iX04yoT3T1J7YC","st_dist_06":"B3lUhjFXTcfTDCh24RhQmzeP","st_dist_07":"KOeQCfsRkrVg4ao289M8zs54","st_dist_08":"ryNWd70xdKDt3HlMUZvKSwld","st_dist_09":"nqGLn1hp2gbKuiAb6VZhMuHb","st_dist_10":"uJdlabe9Xe9gRl7UWKRxrNxR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"S7HNQ96MGtai6T0ntHDmvl1lX7gNYunafjkRVN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1224,"st_w_id":1,"st_quantity":59,"st_dist_01":"ZZioGdwzyuDB1lW7fjrYqQiH","st_dist_02":"1iLnvrIXKayZsZmSAQs0NJVm","st_dist_03":"Efghh0Yshr3YfJrPmF4V9yXt","st_dist_04":"LrViBwYRypl1hvnnmNDz2BRz","st_dist_05":"muE12x9CklQO32h1BQSk1De9","st_dist_06":"ixOrksadMyk8nwy4eWRlBygv","st_dist_07":"f1s4QcahJG4AxfcFVsphnKK3","st_dist_08":"oQSgVbsZhtt6m0JX9iUQPbjD","st_dist_09":"nGPMPhAYaBQ4Ngp3xkf2B5oj","st_dist_10":"kAekLNgYuzIZ86Orqs5JbIh7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6Wi3id841P3NiT0elrpu7vTbolBv2XN7j1Ah"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1225,"st_w_id":1,"st_quantity":48,"st_dist_01":"3lFgT67pOE3U3S0HwvNym8dp","st_dist_02":"muKP7Td0zhyerG6yzDSrRVVS","st_dist_03":"MNcBtNI1NWibF12KgGutNggi","st_dist_04":"GyDJdMTggvmqcytbV3lpxi5b","st_dist_05":"68dtxImWmABOb8NtItvFqnc4","st_dist_06":"Jh1YOnJLOv3tUraQYrw6GAGg","st_dist_07":"d1N1eRjj8RM10qVjY1THtDNG","st_dist_08":"IpbDRfsbSiOjN6lCP43TeaRR","st_dist_09":"3DAzLTAEzyi5FBvLGeqw46SN","st_dist_10":"4IYhif8oGzqg2uMmCh9DZMC5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FkdsbDHQEwM1NBr9R8vJilvtIMKk2nEcHzx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1226,"st_w_id":1,"st_quantity":56,"st_dist_01":"ixYke1qwKcAZlybqnLgKo3Z8","st_dist_02":"PeWzLc1GYGVDVtM3H62xJTfc","st_dist_03":"mIRJe73HiozZR9g6SaSlUMSp","st_dist_04":"BISpolFAYDnaM4n8sMBp0xym","st_dist_05":"hvq89JWeoG1U9yy0WZpwPzMC","st_dist_06":"l1QWJ9dPaLJxYJRloz1c9wRK","st_dist_07":"L3vxuV7HEYzjXktjeUfPNGn9","st_dist_08":"vVtmisa48GIoBwckPKPHhXmz","st_dist_09":"QzAAEjuRMRgl0bLltS9D13DM","st_dist_10":"Bkng8CHq1a1nRlUiLaWYGUD6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IK9fujheBzeOsvRV5tRMJWhhlTgIh7gOQI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1227,"st_w_id":1,"st_quantity":75,"st_dist_01":"R54b5GSmaV4Z2htGoM1M97vZ","st_dist_02":"MiEsFpfZ27X4MU2cYF0Fsg3G","st_dist_03":"ITWkf3ay7l6pw3ktJUHNBYRk","st_dist_04":"eDiU1WadTUn1t43uWXRrLhqV","st_dist_05":"A8mint0pY835qL0XgGqxl0v9","st_dist_06":"j7C6slmxdVRKLuO78BFKzETG","st_dist_07":"lpYPIu0KdzysS0K5l0AZT00s","st_dist_08":"USnzjRQzizLTl3myxgT9sler","st_dist_09":"fxObgcTF8hVLE4LA0xtvj2ho","st_dist_10":"eVPXTDf9STeIbzkFDXteNnXx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"35D2RXXRED8kvUJroriginalwesUlPgyj0PSUTGdoz7Pld2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1228,"st_w_id":1,"st_quantity":77,"st_dist_01":"bMsNLLjEEpsA6kbdaK66g68x","st_dist_02":"kS3BGsRUraTYGpevZRklE7Tq","st_dist_03":"R6u3n9sErbOWH9RzpGPJr7ek","st_dist_04":"BeNbpJdoLJumh9JSppy19z5u","st_dist_05":"bmm4nqeq7jk3pScoadk4HFmt","st_dist_06":"Zx8nYFoUkSVYs1BCCTGsB7cX","st_dist_07":"Qj3kIRNDkiSAGhuyOint08Pg","st_dist_08":"YAhRcamDdCIOsmK9tdQQAjjS","st_dist_09":"QBQlz3Df9UpO8Fu55XmMd9qR","st_dist_10":"rqdLAOqOfxYACkda6WoDj2Zu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"L1MujcgwopG83dZAbTloriginalJEQ8hXHlUbDIKCc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1229,"st_w_id":1,"st_quantity":18,"st_dist_01":"jdkTtUaXjEHtP7JHlKjNW8SZ","st_dist_02":"9SfFWeeqzBPOhgHENTLnPFYw","st_dist_03":"Ni4Ba8358bbDT5ANwO4ijc37","st_dist_04":"5APkkB9Po9Rg0YOtEzPc0rBZ","st_dist_05":"0ei2cDRKiLZmC88Kli7BaIYs","st_dist_06":"Eq6mMjcjKRVgXfO2017Xtp0A","st_dist_07":"vdagrvZvFsSblIWfiFwnt0eH","st_dist_08":"dWUDyw8Q1ktUp0Xyh4mDPEIR","st_dist_09":"6Zn75ZCKCX7BuVchfIBLW2hH","st_dist_10":"1b5jODILkSu0H0IJ6c4k5Ofj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cA2yzEQ2gKV4ZC3q6uAvwWYGVaVyZNbYJWqosIJ46k8Ec"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1230,"st_w_id":1,"st_quantity":19,"st_dist_01":"QCJ2jutAmO3Sli0DMCjwn6QF","st_dist_02":"OjQpV5PfE3CXLba8ya2i0HRT","st_dist_03":"G4yfK0Vjh8jwei91YVUlhNWD","st_dist_04":"dsGqid6I3egi2kz0GhC3wIjs","st_dist_05":"HmkByaC3PmDQ86mondtPG26n","st_dist_06":"iuLW0HFeiKZ7L29PbuwFz7gC","st_dist_07":"Xg9eXXlsHSnJjjyoVX0hL0Xk","st_dist_08":"JHx8WkyphodgI7ciT0TJBBsR","st_dist_09":"s8AByUQAy3osLPN1KOmdVawr","st_dist_10":"0PtDkjJpw9GBHZhsMyajnE4O","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mxHjBFqrue7uVVsGKxWjyXxGzZHk5k45eKg63QSWPefz"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1231,"st_w_id":1,"st_quantity":55,"st_dist_01":"jBKozYqSC4KF75c3zhA81e9c","st_dist_02":"62sKnsSgCbUymf2wfz8RBaWK","st_dist_03":"zsmMDIcx0FN65jHyhHegy1Pj","st_dist_04":"P00T3dkgcNpL03XiSY0c9zvO","st_dist_05":"mamS5uxmyuwbFH6wCj7fhOKQ","st_dist_06":"iFzQjxtzOoV918MhYMVPGARa","st_dist_07":"8uTFmqHMQjshCeH3rB6adTlR","st_dist_08":"5pifkKmMi9unDVdusGEerpB7","st_dist_09":"Dn2Dbii5UNcAMM526eYKOzPA","st_dist_10":"0sjAaTp7HvCHSidXidixFYQ7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NpyoU4amnreqep65qz5ceykArYk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1232,"st_w_id":1,"st_quantity":58,"st_dist_01":"yJRRmI6z9GiCJaF5eNHfPIc9","st_dist_02":"SIzLJR88mxMULefqMz6G7bIj","st_dist_03":"7pr5CXUoPg2sS6JVWBXRUedX","st_dist_04":"AgVAQQyMaXyyz6Bg40upyMPV","st_dist_05":"gfTSiRGNgSsvSGeII69U2MZX","st_dist_06":"cHID433gw72QaduId3AH6FTY","st_dist_07":"8NUwQwjfhlQfwg8tF1y2oBxx","st_dist_08":"KQb3tSaeNzFTy1PDM3MWvF7k","st_dist_09":"N1IFFB7aUvnxyQurkhVgeQpf","st_dist_10":"8QQSfzhB9Q0lZnNLjHLz4L3l","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KEmNtnCP2SGbjNAR8lUODj1MXvhwSFMIHyRQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1233,"st_w_id":1,"st_quantity":10,"st_dist_01":"V31qoivcwRRd4SFmO1TaDgN9","st_dist_02":"n2JzOsb34SVUROtOKyxMnBPE","st_dist_03":"ULqslXbe7Hoa2q7jTGybAuqo","st_dist_04":"2ruG6HpXM96SpqD6WTFefpau","st_dist_05":"DKRJTaCAxA8sYIy7R4gUfXUp","st_dist_06":"64jirgO1VlxhdnWWrF56Lu7n","st_dist_07":"mJ2oM1hVU9KFzBdHd4740RKX","st_dist_08":"ECGPNhg5Dy3Sjaum3Hy7YlGd","st_dist_09":"Eu6AIzoMkK3sY7p9HeCjee4w","st_dist_10":"v1Te0oxOT55usYTaDpWHWRTs","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wMkwBfXfeF8BKq6AAESR0ctLd26MtKsw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1234,"st_w_id":1,"st_quantity":47,"st_dist_01":"Kn0wc6PKucKWOK4E0SOLxAaz","st_dist_02":"CW09qfw64Rk6lRR4SV6RT9cW","st_dist_03":"UyBp4oVFE4qMLxKk5OTbRsup","st_dist_04":"Xe4iCjX4vHoUQ7wGikE0XtZS","st_dist_05":"GJRjDI5JANLeBoHZ1yOvphXa","st_dist_06":"kvwqyciJXX0z3cB3OPxuRHYQ","st_dist_07":"G6Xm7Doe6Q5JypspsVGmS3L7","st_dist_08":"XS2AUqSaN2qmgXP4hjSbbIfx","st_dist_09":"SnsGma9Dok2wh8bk9bwLiU5w","st_dist_10":"FaQdBGVs1OMRipgxOBP0LENe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fVZJBjPZyyanCpCLWRNrBZyT37m2N5i2iK4OWaTdFTMYx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1235,"st_w_id":1,"st_quantity":88,"st_dist_01":"JNB2od3au04HfsMXOOWNYmO7","st_dist_02":"YICT0DCaJdMjIASlixhUvnj9","st_dist_03":"XSLcga1O8AJGRhJ7OMJKk77t","st_dist_04":"zpPr84vx8dSzfERLYa6ncCk8","st_dist_05":"12hCs4CI6OXOoTntZ63sjopR","st_dist_06":"SmNCXO6qAutdziLWnqMwOUtF","st_dist_07":"flXE6OTcjNfKdO3c9HIQnXNa","st_dist_08":"gmG7BJzYP334wwyFZgscVGXi","st_dist_09":"GzRLLZuEWOZZgonVl4lDAtec","st_dist_10":"rQdygIOZWEfnVBmJt8kCEjhZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XqMFYyY0W7Gnp38lWyGYLg7xkVmMLSFMMRTELLr8EhQo00Kh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1236,"st_w_id":1,"st_quantity":87,"st_dist_01":"DCyQQZOl3htjjG97b5Jvw7SA","st_dist_02":"5FE4dHwk2CqBKy3pk4VYBQWe","st_dist_03":"IcdFKKRUyLUrGP25MIBse6e0","st_dist_04":"IEiye36HtZTponwUKvJrs0qi","st_dist_05":"qaqZbwKj9CAmidQeNSPxMuNM","st_dist_06":"qB4lwsn9DdOL8BtZVqpunJSp","st_dist_07":"iJjeg3zpP3S8TZaovsXq0oHQ","st_dist_08":"U34Z1RfJZACaa6RMAWB3PCPJ","st_dist_09":"vILhjjoBiMR3NwYVMKvokS7c","st_dist_10":"G0BkT0D3ODL1Dvl7PaBDoabH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9LvqRH8qfrHzgzpl64xeDvEkmTlasRTEr1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1237,"st_w_id":1,"st_quantity":45,"st_dist_01":"GfdEUvlWFt5lewJhHCD5sf5f","st_dist_02":"UBnBUpuGbvx1JtdE9KY0x8bD","st_dist_03":"CyMhF4N4loX0NrRV7wT2zxHv","st_dist_04":"w1LX1usf1LfAiYHKDZ6K8wGa","st_dist_05":"iwBHpZRG2RNh39ntmdDpPy3R","st_dist_06":"pYDDvtontY0uN9oLPGRBfZWG","st_dist_07":"mo4PqNkbHWjtnuEcNKKR3sRS","st_dist_08":"B5QXInG67ycgMP7deM2WNzN6","st_dist_09":"LLCfjdRRyUp9rVQ4KN2fdbzN","st_dist_10":"nxPGmcETgyYlNzsT2zVOFHH1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"23BEJ4iQH9wzrEQxHoribRICxKw2a5zSy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1238,"st_w_id":1,"st_quantity":62,"st_dist_01":"YrR9CL4LsEN7Baysny4Uos5A","st_dist_02":"bVtBwExpqtcb3rfXGYPcq3fs","st_dist_03":"RNXkyOm3PrHcpCEK3hfSOM7j","st_dist_04":"knJM72tijTgQHBDKYjM6aP59","st_dist_05":"BSCT2nQfH0s1pbNvqCZrOZMd","st_dist_06":"fFkybW4ujnPzEnyCWKvdOiI8","st_dist_07":"KhDqUvcuUnMZIlLf3qkuPoJg","st_dist_08":"j0lUDQl5SwAJ8esP61MiaZHU","st_dist_09":"xNAxrykb7HnT2foT1aqTurI7","st_dist_10":"AhCKMR3LMT2d8EnSWqwbbP25","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wLxHgSP6nRYFP8jqjJCc0R0N6LsAGZCwKyxsg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1239,"st_w_id":1,"st_quantity":53,"st_dist_01":"dJdzqUniaqP0rSLFMJMflrjQ","st_dist_02":"PbPK1FE7szMnBLIrGN4le9HF","st_dist_03":"VzhUt6MVtSUQVZTFLiIxknvh","st_dist_04":"s2IeALVT7GEeazQvJabNCK64","st_dist_05":"S7TGl56ktAVoaLpw3su4hqFv","st_dist_06":"Abu4WG93mHHvYyFSbse8Fi4E","st_dist_07":"7SlaIa2PvTQovhSyBOgcr1OQ","st_dist_08":"klOIBtLQLKfS5pBW0GaSjlZ2","st_dist_09":"wskV4ChmmQ1dvYx4Dso31iTZ","st_dist_10":"YZGuGDQUBfIJqq22abJ7b9KC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BCQ3NGJWFiE04ejYwJrMRLSBYqvUFWsy2RuTGHWGDbahl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1240,"st_w_id":1,"st_quantity":11,"st_dist_01":"isP6oClcIUifFHKcZL9sAdde","st_dist_02":"ue3TCLK2jRSUCFXrLTMEPBaw","st_dist_03":"2t1hoNYsYzhYLccT5vcIePVH","st_dist_04":"hwH8tU6IV9hgWMpMb1Hv3fom","st_dist_05":"41tjgmIRsOKxkGiCTe32sCKA","st_dist_06":"OUqU8JziTKwJ28Zhxl8tDxlB","st_dist_07":"oiqj3BbWAs33PvQ0veiqezEC","st_dist_08":"B9YyhW8t5XxgVJAfhNhQ6Jf0","st_dist_09":"iowvOPwiY5QehaET3zvJEpuL","st_dist_10":"p6nabu03JP96Qau5V3zeqCw8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vbkvMYPsIce9gmVeXsRgZpI06ee7vJ8WVYmOeSKJ1lXhS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1241,"st_w_id":1,"st_quantity":91,"st_dist_01":"uVIRAmusrWo3R3eH1s0fg4ik","st_dist_02":"d0mpx5n9AeAsyTjs2qxjsaFw","st_dist_03":"fDIVGoQZrIJbSjI6bu5S15XY","st_dist_04":"FDpEzSS5JZghuhoLJmzBNVsP","st_dist_05":"rewnkO8hELsNnmjdybtl6WYU","st_dist_06":"XUarfli7tRg8OD0XDEOWaCoG","st_dist_07":"l8HcDOgkk9yID4vg5eyvd8Rl","st_dist_08":"fvJO9anGN9HT88poeRoLKMmB","st_dist_09":"CPeA65yDl0qMy7zjxzefM8zM","st_dist_10":"GcOKluUZCSRDlUHucbzgxBgL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hQZMklkpCeSRwo3G6G2XacrrpWLDUkPq2YHr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1242,"st_w_id":1,"st_quantity":37,"st_dist_01":"sJx2nzEIPQUG1VpzQemjNd8N","st_dist_02":"CfFqbn10oA1eiO3fUs7wszav","st_dist_03":"aRljwgeP0vkLAVAaPGOi6mHO","st_dist_04":"IZHw7kgl3rbkPND9vvrrNt11","st_dist_05":"31RGh467qLxJQ6gOgydZykhC","st_dist_06":"OfCARg9WLQeV0wrWfXxaUEzY","st_dist_07":"vkiNdbfEjEZ46AxBw5DMegVt","st_dist_08":"2UomNKHwxL3CVcolRp80f7bS","st_dist_09":"p9vAat9VWCfQWio9Byndrt0Q","st_dist_10":"hsr88ddRDt01SgxjM1h9nTC4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PIwhEE8aqrt8etQoriginalKApFtFvBhaPEVtBIVP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1243,"st_w_id":1,"st_quantity":45,"st_dist_01":"5Ovs9Tf7kUytIzEQmVOMzZN7","st_dist_02":"7FyrNo4GQgm23WUIOyJS8XOa","st_dist_03":"OlEegnHJaGl2jmFlcJgXe99t","st_dist_04":"1ageyvuwq7fvZVSuF9PYTCzh","st_dist_05":"7FYOvSVwEaLX6bUXtG1BqU5e","st_dist_06":"cm3B8FluqSJYol5drUd6rIRJ","st_dist_07":"WZYeDwaPGDqtlbQkRbuO26yD","st_dist_08":"y4L4nkgIJSja0qKvoUN2Kmg8","st_dist_09":"hEHdisu88VXm49CSA2rHzyZz","st_dist_10":"a3DTFR8L5CSW84y1mHCISNIO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3tpsKwxnrQEHQVMXT8wxMHSBkWJjqNdEoriginal2sjNLt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1244,"st_w_id":1,"st_quantity":64,"st_dist_01":"mqgrckK6Ptyx1BOheSNY44q4","st_dist_02":"NRXy8na0TyWCZRK8XuNgg1nh","st_dist_03":"898Nnhcv3iRshYRgsBX6GAvS","st_dist_04":"lQWqhsmk8puICXSEJGk5VScy","st_dist_05":"ykOjzBWFf6zQB12RvO5tvoUy","st_dist_06":"c3LVTIGXymhfBOBE44YXG7Uo","st_dist_07":"QerS2QPxtybDeK1QcZ1TZ6nk","st_dist_08":"5gA7QN4MwvjCIlKeWzdsQta6","st_dist_09":"OCvv9A1BmsDpzDo3Ys0JQVNx","st_dist_10":"dPMvByPFe35ZcLGrvIwGgaCy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iapydkvX2vRHKRl9XijnATHQ55M"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1245,"st_w_id":1,"st_quantity":67,"st_dist_01":"L9xxWHvlsWTTauKHvtz5WjUb","st_dist_02":"yiZm54Sgv2zGgrco7zEb2y1h","st_dist_03":"v39E0omTqQxzqAdwtbYhK9ob","st_dist_04":"UBeGtQtBLp6v4kuFawAv4axq","st_dist_05":"HVgMtk1p78GaVT9ofA6WL9dy","st_dist_06":"7m9ezVy2Rz6y39C119XIWqI3","st_dist_07":"wH1qPgq0Vc6rEUmJuOXKogTM","st_dist_08":"OtKyvfzRye8fMxJi3IMR5Tei","st_dist_09":"RJTwm7rqMoME46vG9bKHEwoB","st_dist_10":"Csmp8Hbp1B03qI2BWskgods7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"v71VSKBfcXQsAOezTDd7UsEMD9ja2jJ08NcRyEsOn3SwaxxsQ7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1246,"st_w_id":1,"st_quantity":89,"st_dist_01":"dhjgbSqH8LBhS0KlFTkCoBBH","st_dist_02":"ny3CEUEQATNDqi1q47kBp42I","st_dist_03":"WRwOIVPRwgQZDHiV8GtkXrtC","st_dist_04":"bESXkDxF2TiqoaR5YwXQZd0c","st_dist_05":"4jpxosWGbIAN0I1B6dDZHAvp","st_dist_06":"6piXwXcw0qGpGOrK9i3AMpmK","st_dist_07":"Lo3d62mfvsymmlADKmGHKOMY","st_dist_08":"TaR8lLmRTdWNo3U2LD3rDRwN","st_dist_09":"SKX2DGYnWO1dNhrdVaCb8UQK","st_dist_10":"REqiQuT8neGchwM0SPN1nUzW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wPxGKEuDUomMIkLJDTMPZj6P27V5wPFGqWC6N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1247,"st_w_id":1,"st_quantity":11,"st_dist_01":"ETvUG0q10jOh5GqPanQSZXXp","st_dist_02":"2amxetpCQAriIT9Mifa0xODF","st_dist_03":"1rcRa6wddqmNJkAPF7rZvvLj","st_dist_04":"1fMfc5cYwAy3qwc4sxSFUiV7","st_dist_05":"nxgFtyJsHJcOsOi6C9rhkBaQ","st_dist_06":"YpjlxbcKFx9NlhQtSYdIAxfe","st_dist_07":"RAUBMZSqxsYhl5t31AITpxbO","st_dist_08":"rtBPh4kCmCDWdX9gLA8Rf7ED","st_dist_09":"znxBqVhSMD5a13GLCNJzcs82","st_dist_10":"M6vu7kSczCIi5SPxSplp8Sr9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6ilpEn81prpyL1oFkgVs6cFWLU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1248,"st_w_id":1,"st_quantity":88,"st_dist_01":"95mj6mkJaZF9HAOE5F8kpOpG","st_dist_02":"3FEpEYhXbEV9Q5fUFD1CNsHk","st_dist_03":"wfTyUsRchKrXgg9yFbGGxFv8","st_dist_04":"XUUPm2g9H9fExeXa1NgvxexI","st_dist_05":"4XDuOhcTbVGDwbpIttrfjoDu","st_dist_06":"N6pnXTEtJKlkf1rXvwboZVeV","st_dist_07":"ap6MKlz3TJ0OzAhGotsVRQD6","st_dist_08":"uygl8Zb2aUw7NqFu6pCMnfAw","st_dist_09":"HtjRg9Jp3MKkXMrLMS6u3nY2","st_dist_10":"bbguas8PtE1O6JMD5Qd0PokN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FaV6va8FqfSm04ymXVDFogPzDLI8ke0AGyB3mFbA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1249,"st_w_id":1,"st_quantity":82,"st_dist_01":"AroYhmY5pxyQ4wFqqOUANYLZ","st_dist_02":"qRWDLMhOPTHDIWc77gGCJEmp","st_dist_03":"08gdwaO5SXSwJoD0Iwf6uJYR","st_dist_04":"rZ4muml2ils3Lxk2c3jgaRQY","st_dist_05":"Klt2k7v3O3gW9aDMIf8zYlDE","st_dist_06":"3YvPJKVlfmClUqriHjZmOfyf","st_dist_07":"3Hc27ezacoU5oYV92Qew7dAK","st_dist_08":"sGCgBpF6jTkRJF9tzZiKGrj4","st_dist_09":"4t9YVi4lIhte39fs7kvOPeYg","st_dist_10":"Y7MIv7XGMXkHtzaw2yRYNilF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ICrpe91cvgpd9wWe1S7cWHerZ5sHAwTcZG7dAgGXvir4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1250,"st_w_id":1,"st_quantity":58,"st_dist_01":"wxsfaRJkKoqAf3AZjsxmkSbV","st_dist_02":"9NmCETffTdb0tQmN2aYgNaT2","st_dist_03":"U1kKqPp1tl59fgTa6c9YZ5aF","st_dist_04":"VCH7XsgfkplgJGJPVPPRpejN","st_dist_05":"iNg69IDIcGaMMf2ULhoLxRIb","st_dist_06":"TGo8DYjv7LVpctmX5SG8rSw4","st_dist_07":"XTZi4PP4kvcK72lOEdzlnUav","st_dist_08":"3uRCMSFyj8jzZBI69yf7u1TO","st_dist_09":"VNmBb156TdxG7NbJZq0056ja","st_dist_10":"Z4rrAK9OPWSgolLjnufiw8Df","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"946Dc5QWC9uhUq3S6rOchIl7spKKdHpv51FD9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1251,"st_w_id":1,"st_quantity":69,"st_dist_01":"4OQQ2nbjoBtrJP3S5ugqnRWU","st_dist_02":"5PSItyMZbFIWyoUsMGuQB6WG","st_dist_03":"nlDK4azamVASw8VHPUkuuZFw","st_dist_04":"Qxln7ocAIvghsVpIOkPQqZRD","st_dist_05":"o0k4DqbMlK7tiJQxlkKFAylF","st_dist_06":"jtNvCdSoMAqer1DaS5WXzpWD","st_dist_07":"1b2kUzeI47RS5fR7ME7TUgkZ","st_dist_08":"bXMX6oOfALtuhuN7tuS8h1lU","st_dist_09":"mp1SrFEchU8oZS4geqC0lT6R","st_dist_10":"B2aq72pfsYMBdxx2S5MO5HkW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"noSVKDwQW6fSjdktMYzvlHVv5v6yFIx95DGlezq0a"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1252,"st_w_id":1,"st_quantity":26,"st_dist_01":"pJvHD9Pi4HDAh0iM2ECu6ptl","st_dist_02":"0o7fMwnGIVhASAIa28J6jDLF","st_dist_03":"uKISC4wnstf8PSPCxoXfbqjy","st_dist_04":"ItHexBFpsL8DKCfE9IIpBvtu","st_dist_05":"xwE6s15Gih9lNFHiX7NskpDJ","st_dist_06":"DaRDYZTghjzpd8vjx7oAsDCR","st_dist_07":"BKoc5NZCJK8xg4d2TBDGGY23","st_dist_08":"Ic9v1VCYQ3BOBzTEY40zTeFs","st_dist_09":"e7jX6PomT4kzaYRX8kCkRaSc","st_dist_10":"9lGcCH7aB3JHLm1xlerzDuPg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Mib0cqzcVu1NdB2cZ70tVlZI5PJZI9rkK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1253,"st_w_id":1,"st_quantity":14,"st_dist_01":"0P4OVHCAo4XPpOQH9VVDGDrW","st_dist_02":"8tKnoG2UWLzijmBndvuqXBcg","st_dist_03":"mq927GxI5VALeLuJnDVcaKOI","st_dist_04":"HCc3kh60hdq0hJz0UC9X4bi6","st_dist_05":"1sltwGKAz5lTQCIjkbrCS3ZH","st_dist_06":"ELztNhNRDqlx2VGdr95XRoYh","st_dist_07":"J33pQiJ4JpzG9rA7mVUHx89c","st_dist_08":"PKQaQoNBeY5Tsaq2qp2uHGMM","st_dist_09":"Mfoqr0bzkwlrSWRXImaaB5Fx","st_dist_10":"UpMHU2RfL6oWce3glFsGEfhb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"IYl08IiGIRkZMDdFY3KZF6vBaDN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1254,"st_w_id":1,"st_quantity":58,"st_dist_01":"KFthBs0ox22qJQ3BazuzCqis","st_dist_02":"aIdENCBgDzABHzR2pU7mnxJ2","st_dist_03":"nFFrKVjEJPzBD9LHh09iUgiJ","st_dist_04":"abCajkQK5t7RfuB8HZrTSkgY","st_dist_05":"ith812UH2cxNckeHK22K3sYS","st_dist_06":"5guy2y0y2ArObK3rqtPSunnr","st_dist_07":"9tsOVsqiMl464KakJagPrNm5","st_dist_08":"WlXwOlZcaUMUJCXv4MLctygK","st_dist_09":"jnKW2eqRSV3Fb0VL4RpNQ4gY","st_dist_10":"9kKGLJSgBX9KVBTKNwlqBGog","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MvG6UkCqldnPo4Fr69HsP15SinPP1ahyyMDFO7mQqIcXV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1255,"st_w_id":1,"st_quantity":96,"st_dist_01":"1bdT66pzmlrdoVbpdxn2OzjF","st_dist_02":"BmtbmbD7ZGnwvbthJLVYazO8","st_dist_03":"SGXJE6dafV4CqEPl3B4eYqv2","st_dist_04":"SFmB8fQDS1b4n1Eq1r2MEKnq","st_dist_05":"933ShLSI4cBJzj4bNdhPfUi6","st_dist_06":"utXVky2kzOnJryUhl8xVycKk","st_dist_07":"nyf6EODds4tqWRT11MvezZx5","st_dist_08":"Cl1GsoMK7xVMHUYIWapr6tCD","st_dist_09":"V4WrE6oaNPYhVV1921OMru0M","st_dist_10":"w8moxW23XScWUVo1GrZHu3kG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yWSutBr2K68MTWknO695LzcHDh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1256,"st_w_id":1,"st_quantity":93,"st_dist_01":"xjPqu1WcPW1TujvcUVF3Vwkc","st_dist_02":"l0UauF42gaklehlGvTjAXjWN","st_dist_03":"Wi3AjUkdDPUBEzt21S65UCB6","st_dist_04":"42DxpYgcL57FlARPdonJ8NYF","st_dist_05":"L0jUm3rMy6saS061k5ECZYlF","st_dist_06":"vXO8QiDDSsDkCFT3VwNLmxsa","st_dist_07":"SrTbY83FDzavyW13Ei1TJ1Wy","st_dist_08":"OVmktjC6BTl2MPmBW3mDftz8","st_dist_09":"vp8BJdfjqumr9Jt2rJiseble","st_dist_10":"HvMrdCtuc31vLuuJFSIYABBK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YJ16vY2qwoWoriginaloJQnkWKEXtgkMoj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1257,"st_w_id":1,"st_quantity":80,"st_dist_01":"txbCww0JIZ1UTXG3vKYFVGrw","st_dist_02":"UUb9ZSn8cXWSfqGyR01HjVSP","st_dist_03":"ULGVJ0uBF5l9KUERC8onjb9y","st_dist_04":"F1fQbGIstrnrz1mdCYqoGEoy","st_dist_05":"zfHLRL0j8MOPGbX2sUwZaAwj","st_dist_06":"KbRr8A0sQ4Zijrq4ozux84QY","st_dist_07":"eUgxo3ghkRwE1AbAZMx3oQv9","st_dist_08":"Vsy82PzGlNzIguioB8KAbhG2","st_dist_09":"aNWgFT4AbxGIgwKZhprrvC0h","st_dist_10":"xGkgJZrn3NkN3ZfRf4aTbql4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8E3shybwrq2qRf7tfwO2u52XMBGk2R8wAbo2PJcO4JRz2SNLjY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1258,"st_w_id":1,"st_quantity":96,"st_dist_01":"ufMXw1Op5a0xO86dmGxJHCWx","st_dist_02":"9osnFgjxbvZPvYk2EYgzuKOE","st_dist_03":"oWV6gCe4dwJD52perS7RNebO","st_dist_04":"vgNNro1ijltIWbqzmct3J9O0","st_dist_05":"W36p0NaYdRTRK5M9xth353IQ","st_dist_06":"LxuCAp2ZjKMBnoRfESGIPzLi","st_dist_07":"uH9Jb2mcL299qtWIMASQE0ac","st_dist_08":"nleykjg8Du0VCjheXdRGF8Ni","st_dist_09":"08eUDNcF1S4jT3oYMHXib9zM","st_dist_10":"u5WipjshCTNolBydPL2Lgf1o","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VK0nHiscY9L8Fgn8jQXEEExghPin6Zr5UmRlbDoEMprIXi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1259,"st_w_id":1,"st_quantity":65,"st_dist_01":"R9zI8FOLSIfKxhh1bFDw7NRH","st_dist_02":"J6PqLUjdF3EVxRlAziHGEUCU","st_dist_03":"DtOrWG9i32cA6A0Yy5WsnNSQ","st_dist_04":"RRSuitodbqEULUOo9DV2FhtA","st_dist_05":"ijyr4VA0CLacS1VkNeHUz7uM","st_dist_06":"aNIgzMTNtplVVyzMr44zvUKn","st_dist_07":"VFKCRNLNW2ijfB5ioaAtgsQ7","st_dist_08":"S0yFq7Kg0HTU5Fmuppxpvy2m","st_dist_09":"Tw8i12QCSIjqD0JV5QykVtWG","st_dist_10":"RPZFnCF32xNqjE53q29q80U2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"originaljnbxnI5UQMr6o3PdXg20SMAGfIOXi7SkFQ5R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1260,"st_w_id":1,"st_quantity":20,"st_dist_01":"iuLNBEsOLCGxonDAVixMJzl9","st_dist_02":"WCYdGVYmarPqPtUSg6QCwvrX","st_dist_03":"S4sLfenPo24SNRciigDLhmzx","st_dist_04":"4moupb8l0PpKOf0QwsWtLd8k","st_dist_05":"VskkwT21ih1Kvdtnple8fyZE","st_dist_06":"PzokeYHN9CFLPCFGxSPImOvP","st_dist_07":"1CfzdGof1yQwCEUgD3sQmfK7","st_dist_08":"QzSj9BeLSy788xPvUz7m5jJr","st_dist_09":"HDHfRtjl4Z5TG253D2s1eQA1","st_dist_10":"RjEbstHEwoBwnAGVCPwHU36f","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AuWTlXpoYidBRyhTuBn8835rUH46mquzo4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1261,"st_w_id":1,"st_quantity":24,"st_dist_01":"uqFM61g6mGMrddyUqQ4WxYPh","st_dist_02":"e7A4Wr9NxNxI7MrfK1S7pr6e","st_dist_03":"6ICj5Ea6YxjSB8FJledQNgG5","st_dist_04":"rXFQlR5Iuin3isTAVag6YinH","st_dist_05":"YiOitD8DzvxTd7wT3CfWPenw","st_dist_06":"XN7ZQDjhfQm0U22pEXVHE3hB","st_dist_07":"scagvoXXE25NmxUmWQiAgI4I","st_dist_08":"OgR6UTXlSkNbuRRQW01zwo7T","st_dist_09":"jTL06KoHCOLguym2KHrX9R8V","st_dist_10":"s1EtmcZf55MhKveoMin4dIcE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"L36DUVYJqCTVgBI1SsDT5O4YD61DshuogVjDuwdH2YF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1262,"st_w_id":1,"st_quantity":81,"st_dist_01":"Zhwd9Eekj3O16gGLLWBPus1j","st_dist_02":"RNrLexdhSIkDTIGXr0FtDNsk","st_dist_03":"RweLfACmuMal5PdVIwGXrCiA","st_dist_04":"7Jf6WMtplrF6fuxIEGEczPgA","st_dist_05":"YXnwsA7f3bkx2RNsiB2HL0ZI","st_dist_06":"INHYB8ivwmDTYP5PYCUgg9kq","st_dist_07":"joTujXe74k3JszQqtigVX173","st_dist_08":"7LOwGfTURTk0OolW1uyblRIQ","st_dist_09":"gAM8Ua0P4FVLOmigRQe6Do6N","st_dist_10":"fcselq5IAczwHk2DXKnYBNL9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lqdD5Th5ks9dOdG8NLzcW04original"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1263,"st_w_id":1,"st_quantity":19,"st_dist_01":"ejUwX206yKt1XpwLq3dcTMk9","st_dist_02":"NrJBw6oI5PzZOOT9NxRu1hhz","st_dist_03":"NUJAJllDtbgXf9Jagrct2CIT","st_dist_04":"UN8BQJaJwuhhQFOL8S9f3owZ","st_dist_05":"6i4Ep9TDr5LlniPWWu1JuFE8","st_dist_06":"HegpQwphlysgsVG7qx6fIb4F","st_dist_07":"KgRJqp3dNnMWCfydko1TJyJO","st_dist_08":"nhWfxLnGgjO2aAcszqNQuEuw","st_dist_09":"ObLMEmJVT035KepOX3KCL0zX","st_dist_10":"5gg2HentXtMUwuixJjNB6AJ0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Wozt5tocWQRRpPbpWjwjvryyu39hSPTBbp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1264,"st_w_id":1,"st_quantity":38,"st_dist_01":"pU6WFeLtzBUije0fL0MXajMh","st_dist_02":"gjSOooBgCmEjaOj30CfsFkl2","st_dist_03":"34SAJi5sNY0kqnlNzT2rkjaj","st_dist_04":"HDDAdOvMgqdWSSHHJX0nVme6","st_dist_05":"A8kuy6HhlzHeXWmX9n2GOr47","st_dist_06":"ABdWwq2vi5P9ueOCGdHvQ4Hz","st_dist_07":"NUDHuQkR0ADWCVDjZXYwJ9MV","st_dist_08":"SC7rlkYElR0BZBuHJqcqpg2h","st_dist_09":"mmpl0hm0S9nztSi0cjIpxbiB","st_dist_10":"DT3LNlopE5uAhdeYNzvr5FJr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"be9Jh4IBQAm9YK2GMqpnQLMyYEcG1ID2CFXt2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1265,"st_w_id":1,"st_quantity":29,"st_dist_01":"bW5xv6vJRHddkNI7VqmkRJjr","st_dist_02":"Zlx3ymjOIbDc0rm5hmkC4siF","st_dist_03":"bROCOllgRKsrUy0fJME0yh2I","st_dist_04":"9fIpXUtVccjNAMYy2KohltDO","st_dist_05":"F9EuZpDceftluTLib5KluDQj","st_dist_06":"XARrqP5zUS6zZf6CudpV2NJ6","st_dist_07":"eawF92H3l3cfVz77tjD3p6xI","st_dist_08":"BHTgT3Xty36tzkWVZQ2Et28X","st_dist_09":"MkGqMPonNGCIWbpwvMtWheRW","st_dist_10":"8bMWf229gxa9eWrnOtE6BLEI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6TS1CtwKyXNwm3boeCsPSvbyXfnZh6zrHNvsQEEmD5Xir"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1266,"st_w_id":1,"st_quantity":97,"st_dist_01":"aYsyM0LzVnGW7QB3y30s32q7","st_dist_02":"zYlJhGk7h8oYKuVoklvh3HNg","st_dist_03":"yDOUr0iyEP6Z5PhVt7u0scLI","st_dist_04":"qDvip8C9349ERCHR5KP3OJGA","st_dist_05":"k8FpGyqpKGDSOVQuhH6FtcdC","st_dist_06":"oT7YjzSi8Qc6wFPKYmRf7Sa7","st_dist_07":"5FHXTa8L6KwzoBboHY1KgICj","st_dist_08":"5znEL8QWMvPh01F3yeCQbFPB","st_dist_09":"R6tJTSxLjvo3vpZuAa3rQOec","st_dist_10":"u9swEvqrlGwfGOHteKvnlmdR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9DPywoHca1bEnwzxCQh36dJsHRX3UW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1267,"st_w_id":1,"st_quantity":11,"st_dist_01":"AN6SAI0D6GghRzTQ2CjUwhYY","st_dist_02":"6X00Ai2ruilsKd7EGIdXZhcU","st_dist_03":"yteArXD9FZb9XO91Ir0RNM4h","st_dist_04":"XaaBxviGwye1UBiz6J5LSIxd","st_dist_05":"J3WCVCBYOBkwokcgYD3D2I3t","st_dist_06":"Q6Dbilqz4TZuFQOCWpkgTrGA","st_dist_07":"nR8FXi0twU2WNHWrbHGY2eyM","st_dist_08":"47ERytupLidy0wxQL07jiQ9n","st_dist_09":"4LHg3HbUg1kdee5E0l5cKPvx","st_dist_10":"aJoVhRpzCcacF9QSk0TXRGv2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eCCy2HTJRfSX0EhNhQGbAfKBXfz4LlkDv2xeO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1268,"st_w_id":1,"st_quantity":94,"st_dist_01":"1Ac0ulPXReANE9HR2FlV3h8O","st_dist_02":"QzsWVIGZi1YlJjjmtGL9fhpQ","st_dist_03":"bAEZUMU0MLDjf0Tn6EpXCiia","st_dist_04":"SnXDYNM5TAY4EWr0S4YGlAN3","st_dist_05":"AQSQ6B13pHbxADaBtoaculc0","st_dist_06":"3HhQ3txYSqFWbumsAa2JmwID","st_dist_07":"MP5j9CJvfQuJdNbyYlMnfZ2c","st_dist_08":"o0oCAyMUpMAA2j5EfS2lAA6Q","st_dist_09":"KwpjEKZE13qJGlV83mViwN9I","st_dist_10":"54e7j4GqDabqJiEyyWJQF4fF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LbJi1Etk62oJilQ3VaSM6wSarrtXY6405YZwmGMtj2LiBKThW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1269,"st_w_id":1,"st_quantity":34,"st_dist_01":"V0jGKzRgemIIkZco1Q3CePHg","st_dist_02":"z9AJnQKLpXVm1ubjLL2pYobV","st_dist_03":"y3NmxcYDe5TP5VOPq8uV3KwQ","st_dist_04":"Ksp2Cvusx8HC4eYdsBJCex1c","st_dist_05":"avLZWkelLzcF8ZUyeVrwZNbv","st_dist_06":"YAhvr29JDwJHDOvkFQt08BIr","st_dist_07":"u1M6oujhhHZEo5i5dBwBPOu0","st_dist_08":"pn3gnYt94hosQIXGSBGiMiTc","st_dist_09":"D2sXsQIkElXn81UQGTVxfsa7","st_dist_10":"EynwLc4neQ6ELRzlswSpu41Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mjWUaTTfxTIOUxrbADIVG7WBRxK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1270,"st_w_id":1,"st_quantity":52,"st_dist_01":"4M7QVwzAOrWK962nqe8I2Y4b","st_dist_02":"T0XGaU4xAAa7sfiDp8DUZggx","st_dist_03":"ZD8MxMtuF2V1092K5CDo1CoY","st_dist_04":"kf7Sv2BZcPg5wB3N0hvDgkOd","st_dist_05":"BkjMnqyE3l4RQW8QooSRc61P","st_dist_06":"jwfcMaJUvxYEjDkxAdx1k1MZ","st_dist_07":"z3QBfJ7Gue9uwCCbn4ztkd2m","st_dist_08":"ONChu6A36iCufMgXJMOcSGDh","st_dist_09":"PwS3bp1TqAMeUQM7Jut2nHve","st_dist_10":"ZHLndDHWq3ypHIXtjwg8Wuy4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"q0SGxCR7wXIfT7koAfyacSsPOw3lwbaQpFz3v4XsXbClll9H"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1271,"st_w_id":1,"st_quantity":21,"st_dist_01":"DrZHFOvvMtUizH0g7Yx9s7Nk","st_dist_02":"V8L44WK9Wjzpl22ItDzMm35k","st_dist_03":"ONlKrjFEcTDGDCttA2JjxApu","st_dist_04":"0HHADojqVFqeZyyvwdExzRbP","st_dist_05":"Aa0QpMOFydaYkJydMObKgITg","st_dist_06":"VjFcMWveAO6iFFyNFjPBkbZ4","st_dist_07":"vgZh7G9XY2h8ioKJZidICdpO","st_dist_08":"UGQDl0HAqlliAMDeznAhxMQA","st_dist_09":"tQ9OknPQt4blJg5JMOyab1rh","st_dist_10":"kNjwaL8DL7tYaLAK9SnmoxLK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ate5BlRCvnfPplKhhhUc4gb8r63w5u91UVl43bK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1272,"st_w_id":1,"st_quantity":79,"st_dist_01":"AfftzYgov7inm2x8gN5YBIHN","st_dist_02":"0grtRnmbuv4UwtMyCH1kLCll","st_dist_03":"5LNjcyW5XU9WZFHI5DE4seHF","st_dist_04":"6yig9BAMsF6GqJZJnyw1az9b","st_dist_05":"FjYXAftRNeWMVUfFO4G39uHG","st_dist_06":"FP8oy6TeMTekt8kj7kb0Buv6","st_dist_07":"QnSMkbjqyr2Rw3FHWCQD5PSj","st_dist_08":"appaFyGcuaBABJQGKGx7fdjp","st_dist_09":"MFpDyF0zmhUqUfEGvLnqKhlJ","st_dist_10":"NuuJhHoKRWVGVmO6bpFbR5pE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RSfzLiuvq9CioY2RTwMTp90e41ZdcjZR1nLrT6En"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1273,"st_w_id":1,"st_quantity":24,"st_dist_01":"rPWwSpOWO3NJ71nfEIxqcw4o","st_dist_02":"sbgND1DQAbjbtFZY2q76dfrS","st_dist_03":"zU0k6GOd9o8YHg9n9nll4jqn","st_dist_04":"2yV7rBj0kDxCLBLYqAqLsb4w","st_dist_05":"LSDHM4iLegzkO3B2FyNU2bcx","st_dist_06":"8ij9UgzzQ8BxXDyzXuJHRDd4","st_dist_07":"Rm2pzmYYIs3UDUsKBK9nrfJS","st_dist_08":"5tWERJ2ZaiF0OnN22H8rtH5r","st_dist_09":"wH44ylROzp0P28KvDJMXIkaR","st_dist_10":"bL4Gfkc4QvwG2rMGDM5U4m4c","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5q4ZeUkHnhuljGGidbhhngxFmm0mPOD1WytMmd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1274,"st_w_id":1,"st_quantity":15,"st_dist_01":"Pq9WFETuzXi14poQ7Pu5wgIy","st_dist_02":"3XrLGZe4pEKDeVgeMOJX1TNY","st_dist_03":"1xlJeEqFxdOnQmWMMaAXMuUt","st_dist_04":"Mw71PFFZOhjfKe9vyycgW4Rm","st_dist_05":"2k1Eu1eJnSm2BiMEpXSkndFN","st_dist_06":"76QzSgsHESJIvU17fPGLubD0","st_dist_07":"qngfALeOWyVAalJl1klte1go","st_dist_08":"nxJj5qPFSGm0IoOn5kYN92ZQ","st_dist_09":"KKrlgfbVcS6dGEvsyqKBMR13","st_dist_10":"2LYX7sRww8I4RWAHJlsaYBW2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LAeqHhXcXcQHQ1rQtADxU9ldpotg72nBQ8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1275,"st_w_id":1,"st_quantity":39,"st_dist_01":"0OKWPzqWUrWxajbU3lmPO0nk","st_dist_02":"YvdOIg5WpNirma1VytTAi9Uf","st_dist_03":"VJ0bxgb8zktgFz9NUP2pmG4l","st_dist_04":"oUPhRH2DCg2SHQWx6Kpc5iZl","st_dist_05":"zgPIlSh71LjGnMxMTbScZJG1","st_dist_06":"zatlIBjk1RgK0CO51in0KKmP","st_dist_07":"VxIapAonYQhAZQnQikYRG2gr","st_dist_08":"GyQ1mpEli0IfdVCCbXN96By5","st_dist_09":"S1SzjWMpPHaX1IFRM8NmuoN2","st_dist_10":"Wy2QmpBSAWufbYzKgwtddemH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"psB6HTgblz3qgVE9pBugV4naLJgfKbOzPBVD0W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1276,"st_w_id":1,"st_quantity":55,"st_dist_01":"pscsy8SvdELlzVguRVC0wNrX","st_dist_02":"KYCOj8qd6Bm7lXjxOntvTuFt","st_dist_03":"tdcbGMrzcO0sqKIDnQZs5jDT","st_dist_04":"ax3POlx8hlRmkYQmvfxjDV7D","st_dist_05":"KAq2EjlRVxkLPNSWKnlM7yur","st_dist_06":"a8cxgnI7xcJyem2e2p5mIrw7","st_dist_07":"PI6Ota8NuDBEfMeaXV7Ht92X","st_dist_08":"gJxVqKB0PJTiz5F3a39c9Vgk","st_dist_09":"hDdqu7iI1On2ZXHUW9HR5hWM","st_dist_10":"E8l2HIE9lMjDOUjI8luDUlIb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qKmZeK2ir7MhhL71kSwWTy6yuZlSJuJjmTA9GMK9eMT6p"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1277,"st_w_id":1,"st_quantity":77,"st_dist_01":"4JpyAX2O6G8eb7vFNRhlb8Sc","st_dist_02":"MYQr1wyAhjlk8qC7991LQdy5","st_dist_03":"ag4kzCwRa1LwGOtMS0jIKeV8","st_dist_04":"FKpwR9t8w2qjuvMNbhE3mpCV","st_dist_05":"lSvrMKpNFsWkPEru5hmp1Fby","st_dist_06":"t2qL2Up8JMGWrp4QfLF4y0iV","st_dist_07":"tEDbpQElrSANgyS53oRGf5MX","st_dist_08":"A52jpxdr8Z1Z7ycwwKOXvNUp","st_dist_09":"Ip0iLOu3apGP55ESlr01xjOb","st_dist_10":"NWhAKkHjXUtZBy6APa3qMWcz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3DoOBBSoyuPIX9JZh9FF3bvK57aPDEG9Qm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1278,"st_w_id":1,"st_quantity":80,"st_dist_01":"Y2U93gvVYUjn7fZhV7YUXm3D","st_dist_02":"GECL4octJFmeXQknBDiy4HpY","st_dist_03":"9UYx9aLnWNgsNbtuwmoubonz","st_dist_04":"pu11Eiw0ZXV0m7adIC0sCJSP","st_dist_05":"aHlU744wjfNqtuqL0BuP3Kio","st_dist_06":"p0okJIqRx0ROCKCt1UU4x3Oe","st_dist_07":"mnRx07smhssRhVTG1euvSgHz","st_dist_08":"tgJVWPdKKemyoHLgketQNlJH","st_dist_09":"c9gUxb49SSp1c1ZVyQUMhtOc","st_dist_10":"O1uCBuGYDlR34pP1wIrMlsxe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OK8INMG2Xp1LlteXjKfTyIEZIX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1279,"st_w_id":1,"st_quantity":53,"st_dist_01":"pQlLmfBmYACLVJZtOTlaobqX","st_dist_02":"zFKRyexGBjH8dmHKwVd9uFrn","st_dist_03":"kPE4j7PV3jFcpscMnWybfqnw","st_dist_04":"Sjufe5McjzcYusN1OUdE2NUR","st_dist_05":"PFLBighXNQsTzYUJe5gQoWpc","st_dist_06":"cRbIfDDhPq7rkMZMFbgIowrh","st_dist_07":"TtzpmTshhoLsv9mKeAEPYdMn","st_dist_08":"9MDORZZoQ3lyAtZLGHAl3q5n","st_dist_09":"Crd2CZcoyVRYeLcTjJ7kNQDv","st_dist_10":"hdC2EMaxAIxMl5IqobnUBvuP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BIyI29T72JRBNt0WgzNNKZvltxfeQOF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1280,"st_w_id":1,"st_quantity":55,"st_dist_01":"omzNLPHNLSZUxmcrETgKXx9f","st_dist_02":"4i34devrDEcAoFVWZjtQt2pA","st_dist_03":"4dOC5bZeQWM0D0poTjn2cTi9","st_dist_04":"NQLm3jORqTzMPngzBtjaQtQp","st_dist_05":"aDMkvcVT7Fv3RYaGFoJSn0Lw","st_dist_06":"q6hotpQ1bRuomKC1d903W3SY","st_dist_07":"jHDI2S8hvlBBKIQys8GxzgEo","st_dist_08":"XTyWEIAAbMvbUMn1qPjChtlj","st_dist_09":"npe7tP2w9vkFoNEidtG0PHr3","st_dist_10":"CyTTeHjDxOoUFlunIAFj1C2h","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"EEMsiHV8BQZUCTojxAkI1tqlxCBu3NaLM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1281,"st_w_id":1,"st_quantity":72,"st_dist_01":"ypTEpYoZgTJFeKYwAIjauTmU","st_dist_02":"tVZuUEPMFdwVQKFRViN0GSnL","st_dist_03":"XKQ3bIwSilUTqjw7HfmT8amj","st_dist_04":"jp1UR6wd4W4t7Zw6DggKXyEZ","st_dist_05":"8DitqVLVNe1LZuXCp0nqQLor","st_dist_06":"eQUOGVCc9vhQFnWPnEUaFG6k","st_dist_07":"H5exbRtth3dfRo1LhnhOeDL4","st_dist_08":"HNKZrmVKFXrLR519MhYBnfCz","st_dist_09":"i8oF5VY1gBYEYmhqx1KQUZz4","st_dist_10":"86y21GX4qiRaDJKbDWM0uYz9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nqSEt8VncMEggs9U7lCT0mhrwfLN81LZyPmo5BkV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1282,"st_w_id":1,"st_quantity":18,"st_dist_01":"LVcNGWeGUJ4ThkhUmuDGy48M","st_dist_02":"eMOuwdF88BtlGF8s8wzF8LKH","st_dist_03":"642s4xiZJfiXwuVMShtVJPuK","st_dist_04":"j2waAC74AMy7zq1P21BGovzN","st_dist_05":"uiRFE5oc2V4nCBTAUTT0S2aZ","st_dist_06":"JlVhJ2zETYCABgmATUjiPiGN","st_dist_07":"T8gyXjvGOieq1sU1anJvZN1h","st_dist_08":"rsQqWQnoEWK0TaAZwKc4fSsx","st_dist_09":"ewvuIturNYbZ8a1ywDflMjBz","st_dist_10":"AzKcBWATeeu5LBm2byJBiS1a","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vTLWsK712j75X7JcsCXnahFpHSfaTIiAkMtIEBNq5W"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1283,"st_w_id":1,"st_quantity":92,"st_dist_01":"O0f3d25Int35lKUb4As5juqO","st_dist_02":"vTspC8kyWcPaJyUiAO2Vos3g","st_dist_03":"TPhUFE3omFKy1Alt1v3GECck","st_dist_04":"ty88uuFT1ggW7gw41KGxU6Xq","st_dist_05":"eCwb7mFmUDLpK9WSg6kDFed0","st_dist_06":"YWQlsSyZSVyQuG6IhLnSPUHh","st_dist_07":"U3FirSY6GJTmfLx3iwUYur9I","st_dist_08":"7XdpjCBRoeC7pKmhVIpvdBDu","st_dist_09":"twREJk9xwPYYgeD0ev63v1q3","st_dist_10":"l5Pmp0kHdsOWCwI2UVHQ7bUt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PI0dU0lv0JEilmGmGkrgXRwA1VtxT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1284,"st_w_id":1,"st_quantity":50,"st_dist_01":"t7Dg1KBWJ85T6ptuzoFAcKNf","st_dist_02":"RPoft8p435kfJ1C06X1nWB8J","st_dist_03":"WFgtmQIuZK4VPdNyUASDBONu","st_dist_04":"zLCAGiZ9YJcsy3aeOx5pw2S8","st_dist_05":"bnt7tZY51Vren6v2shGDPxzj","st_dist_06":"MWCusyASxgn420wusOAEYkHY","st_dist_07":"fnJXPHUV0bG39aLJ7YUbJWjE","st_dist_08":"TPPbAaKtmfsp4yg2M4XAhwur","st_dist_09":"oTAcBNQ4NaAALPsOHp8PB78E","st_dist_10":"MBtFV6lsH2HdQZh7uWxefbFF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1QDQvv4FTosZ2hblo5umvLiOjNRoriginalsj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1285,"st_w_id":1,"st_quantity":42,"st_dist_01":"9UJ76k6efdDk0mMytlHBZfbW","st_dist_02":"RMXPgh9BfMQGIZVFhZuKQEHw","st_dist_03":"CStmQ1W2WsX9Xt6Bb14iWzM6","st_dist_04":"hW2UHZnKyRGpAtR9bjSTjQSc","st_dist_05":"H5PWwtrwsVJEjwzE4Qa4tgy0","st_dist_06":"BMIIM2oFbZhbTaD05wnJPDUt","st_dist_07":"V3pcLUjZdAtPC8jn7Uj2nCgM","st_dist_08":"fqRNzAEq2LpgnieFUk9oLwIc","st_dist_09":"cWdJWa3kwMB9D0BujpyO5usa","st_dist_10":"5s2iPBRQGMsL2J0I7DgaYgin","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JHRLgnayIHrtJcgYiNNoDC9mnFx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1286,"st_w_id":1,"st_quantity":37,"st_dist_01":"8a4UMwpl5i4ZmYDW09oZWmqx","st_dist_02":"lBp1yIwYWvd0F77uxQgm2mBy","st_dist_03":"rcIbCndu5bf8zwVNXcX2ZiU8","st_dist_04":"LajqTPuZIdsAT9SOs178EFem","st_dist_05":"EiKYZ5hLXnVOChCzIo8W9x3g","st_dist_06":"GeJzEClnmHP8Vcxz9r10sQRG","st_dist_07":"2HsMCF1DGGlqd4bPAGLaRluI","st_dist_08":"y6EvjX3tCWxPa6uPhjFI4I0j","st_dist_09":"luTmBD7TZeqDbuJuUIbR6uPT","st_dist_10":"LsYoBe4rkNvlwwAqfmc2hsE4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ri3EWns7Es9cFkZnVASgLdfOGeI"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1287,"st_w_id":1,"st_quantity":90,"st_dist_01":"f5fkXFXCjg5iBEyA7ztFvC0i","st_dist_02":"fUbrXPHfUuh3xujtfe6gpPZg","st_dist_03":"rHVLxdCXheQVlqQaWexpnzeg","st_dist_04":"LR4NL9h0JHJUNrNSXUjInKlz","st_dist_05":"OM2vSPvdYTywUOg8S9wR5yC1","st_dist_06":"XPWYFPaXdBPEqtbYoNhFVsnL","st_dist_07":"ergX344ycO7qENitmjROkzKN","st_dist_08":"PoQcX5cxW28OsfU9duazyHbV","st_dist_09":"udSDslL1X45AkI6XSDPgJH3r","st_dist_10":"OkHTz8kOxVF8SuiEGGRZL6fS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"oelgYoSmOUSSoTtl7BO5o1Nzy5uEvjroeztnlf9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1288,"st_w_id":1,"st_quantity":79,"st_dist_01":"G4AQBWAbdygG4FjCsn75l3pB","st_dist_02":"7qZaXtDL9Y3q4xIS13qGNbG4","st_dist_03":"JXHKij7gfVM6gNUBHASkIpeB","st_dist_04":"SIB2uFRFw6Cjd19n7tOGFFNa","st_dist_05":"Llug65BMDW4nGjoBwm5OG9bk","st_dist_06":"zsQo5ujsRDQxQICrPwrlQICZ","st_dist_07":"z2DfDv2hXXmLuwqtrBqksnAs","st_dist_08":"71RMMPjnv8VEnhNOlkSaMuSr","st_dist_09":"zGczXBUBdbSv5v193kpfPseX","st_dist_10":"6Gv4aZFJ6KF59TdwkH6ANvKT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Q4ez6wQT6RZaR1DT6original35D3gtvaOQZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1289,"st_w_id":1,"st_quantity":72,"st_dist_01":"AG81WUXb0gaKlcE6dpwGqTV8","st_dist_02":"k9vUdTkV7OEow525GIgbfuTS","st_dist_03":"ma4RwPvZ5BYarCpis5ZhYpWt","st_dist_04":"0WJr4JrK8TTKkg8ceZZQ5Cxr","st_dist_05":"I5QA3qDUmhIMPt2OpZofl821","st_dist_06":"6LHfsodd5LT1LgApK1JXlsJ0","st_dist_07":"YGBWND4tJa5oQDXrKZsZjZk6","st_dist_08":"GZI8bPb7pK9bP5e1kE57DlCR","st_dist_09":"wFLc91Hvp26IFW6m3rmUKGJn","st_dist_10":"XdO8NbWNp5yPxZD4zY4V05OD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UNpocO4ipZw8PoqGNZopL6F6XWR0wKkR4t9oExLW6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1290,"st_w_id":1,"st_quantity":82,"st_dist_01":"SuajvlI6usUAYF8KrFIVSAg0","st_dist_02":"qohwJyS7FB6hFekLKcM2iVWK","st_dist_03":"VR6FuxxC0rNXwxC35bmupI82","st_dist_04":"hTBRZGgYVzTYYkhySo2adDBY","st_dist_05":"Oz7112hhkqHRLgNYZngPI5IX","st_dist_06":"cXP6Vr3I1rXS1rjiGeHJM28m","st_dist_07":"qh0cCMhgXeaEp4B3rq1QIbbE","st_dist_08":"i9eAZPH6FOlihw2Drf6XiA9y","st_dist_09":"YbJvZegWqLU3YCdchpHjFhRR","st_dist_10":"9XofZ3UmBxsJGOYeFqUN3rN7","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zUpM8xhGRiNJ4sjVAp84qqE8HD8hAO8RyrtC1TOlZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1291,"st_w_id":1,"st_quantity":93,"st_dist_01":"BLzlBVhlR5pLtOW09GoYVnB7","st_dist_02":"cCMsg5RckmvglVvqLIc8ASeU","st_dist_03":"59yNJggsgFQn2ZHYDFzMhPIX","st_dist_04":"QwklTpbEWl3Lyiq4NblYmbfv","st_dist_05":"RLBOj5d6D5Qq8zliMbFOx8ge","st_dist_06":"rIy2pdF7ngjSYKcT6RlQn0GZ","st_dist_07":"JC0C1o5A60XPKjtl23zLLKvK","st_dist_08":"RWawKdJteNI1TwCdRe71KicA","st_dist_09":"ms0veppNktbGpT0FqjazGUJg","st_dist_10":"ToX88N1C7LiO13csbPKLWG13","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xawcEtjbRirLMrxYB29cDwmMm0qLaNZ2aqDYnpfP6NBXob86"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1292,"st_w_id":1,"st_quantity":40,"st_dist_01":"FizWJUxd1tZx3D9Rsw0608fw","st_dist_02":"jhI7ZhalSNx6S2INqcRKUP7A","st_dist_03":"W3WQ5Eeq4hJQgQEf9JbRBAqh","st_dist_04":"J7DQejWRp0I6DoiJ0E6fTPBI","st_dist_05":"3hLnIDd219BXPhYTcXV3mhND","st_dist_06":"lut4GSlu0MyKS26FZ9dSGnH0","st_dist_07":"X2t1inCLirAhfa0yJJU7NGIQ","st_dist_08":"Vu2KVTP2jWLSpn6OmcpJPOK4","st_dist_09":"d29YwpfNJZGjh5oyTRwRwqcJ","st_dist_10":"8isIOMMcawvp30XKXNQq7yA9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"original0jwmgKA5BjZpRJAHtV2VZIc8809Q"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739245,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739245,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1293,"st_w_id":1,"st_quantity":43,"st_dist_01":"ir33XRqMXOHydnqhWeAJAHJh","st_dist_02":"2XlG9ZK4Xrh57c3gjr7N28H7","st_dist_03":"TgUez706dn09vbCahA7MVfkO","st_dist_04":"qiHJlGYzRdQw0ajh6oOwycpJ","st_dist_05":"LIHZk2S77Vz50mRjjJXIpWLc","st_dist_06":"WCNQzs5wScwrpLgCezlJqd1q","st_dist_07":"eE2PLsNuHwINy5qhUlDdkjjK","st_dist_08":"uAPXzlWPqPGoHQLnoCiROLW9","st_dist_09":"3wuPzk0fiTJKJG170bDpcF9K","st_dist_10":"wIRmOriT2A1SNeuVGGk6hZxo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cV867e08SpdIwnJH26Cb1rHURaA6m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1294,"st_w_id":1,"st_quantity":82,"st_dist_01":"B3TkDWTmu3MRCt2fv7kMK5tJ","st_dist_02":"HRcs38D6867tSpnPpj2W8NmL","st_dist_03":"42dqpXJuNcG4ENzx765oiliN","st_dist_04":"b7H6gurpyqtrS59LUofxE2zM","st_dist_05":"DXq6W2ANlAugzS0q9CmttNga","st_dist_06":"kImo2IfayA74SUmOsqOEun1U","st_dist_07":"spUQspWHrxc8NqA0nMC5Lrc5","st_dist_08":"8l91wC6SjBAXL1Gp6gCklwEF","st_dist_09":"Y8RMnK26B6qrrj0ezNCTTb18","st_dist_10":"GuWkLJeF8fbMBxmekWyJtOy1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2AxbfjKBfGfn9vR1RlNspM6162iS3hOKb"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1295,"st_w_id":1,"st_quantity":60,"st_dist_01":"KxRHDLEzOxJmVLzmBcihK3iQ","st_dist_02":"EsjYQx5jc7kbVKkMYyFFEacO","st_dist_03":"1Lp8pnnE2iAvTfNUwjE5ES0y","st_dist_04":"4QmXDM9tIVZZ3FRjqudnVfwF","st_dist_05":"Pshkh0c1jUNNgtZ0EMfKkRg0","st_dist_06":"yfWEWJ2RfbigY0VXUaFPbI9Z","st_dist_07":"2DOwjgKkpFb14heCHogZLGSf","st_dist_08":"yCCoMjcyMLSV7ss5nOcZOCUY","st_dist_09":"LKwdLACpV0FyDQp3aNr6Svh1","st_dist_10":"f1FnEEPYxA4bBB2kjIteyJ1W","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"41CWdkDIWMQJVOGAoi4G5iaKaGygRV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1296,"st_w_id":1,"st_quantity":47,"st_dist_01":"il871nnvWW2uMvfSF0C9GwM7","st_dist_02":"Rz4hawGCkaYlCJwT8rYUXXn1","st_dist_03":"pRLG92vFMbIy0Mr62Idcs6Oz","st_dist_04":"XMIYugzxSlWP4mU1r6xUTEYF","st_dist_05":"Id05YFaAhlH8tlDFgyoYVI6z","st_dist_06":"cv7NNTIN6wXtDtbuShoLHwKs","st_dist_07":"lwaldIDVzQOAWK85ZJ6Pb7Bn","st_dist_08":"H0Qwv0Rmo4dHhI320pQL8h3o","st_dist_09":"ru6uac63ecStHfs3viGHKPaR","st_dist_10":"QTaFYkvt8uf9bl97QUmC9L1L","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"hyW970gG7PPBYnx4Gi4dJU42sid2tfzKc13jZeF2QAhObetXM9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1297,"st_w_id":1,"st_quantity":59,"st_dist_01":"sJmp4HdyNOmYD48FxtB66QGG","st_dist_02":"pLVOQ0zPmXlmuqUHmdxoLw2t","st_dist_03":"OQeDpt2xclFcCfPkYeFtbjIq","st_dist_04":"zn7xlvlqdjaFSGb3BKlUdzTR","st_dist_05":"S5fBjLftHHyFTd1dMtvBHffb","st_dist_06":"2lhkR4sjttQMMr0J17kUyD4V","st_dist_07":"pQ7XdNyS5MLiGp5L1jx7vIMk","st_dist_08":"sXGkuHtMrH7lhp4Qb3lh8GlG","st_dist_09":"HSWenxnIoG1NTJmVMYLj6uFm","st_dist_10":"nNrCjIrX174DJt4kgDpa7IPb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aSHOksm4tRog4hsnsMHhfM6hrT0ckxzK5Kx1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1298,"st_w_id":1,"st_quantity":57,"st_dist_01":"UqL53mg37vvZUBZzwHEKtPdF","st_dist_02":"M6NwTj7K3kzIcMHWRMcXDiHm","st_dist_03":"pr4r8DzTasVsfUJ339yTjnvW","st_dist_04":"4Vp9lT8TjwwaV6tqww3GShNy","st_dist_05":"00bXFz7mK5RGa67kYBjjOwii","st_dist_06":"Ex3wXsx54xoR3zEvZ7h5vhUQ","st_dist_07":"oosr0FljUXN2sarW587KaNCR","st_dist_08":"44Cek03XivvyIoeggnkve8zQ","st_dist_09":"LuK8uJDULDuIEC2OwQ07tivd","st_dist_10":"WanaDabxqNz5oqOWDHFePI3g","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"odA9HtP1wsnFgWwE6YK3uQf9bsN6KVYWl7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1299,"st_w_id":1,"st_quantity":81,"st_dist_01":"vqML1SjD5HtH9A3cHdrRVUtS","st_dist_02":"dD8vhleVy5UyfiX7c4ajF69E","st_dist_03":"MWS1YKt4jnY0wWkOHIvzkCzu","st_dist_04":"uNSbnMunLasZuhi0nWY1fiTe","st_dist_05":"vgD2Tm9tk1PIH8TlZMVZezk3","st_dist_06":"DpUGGL1G5FtmH7gPyvlwoJRW","st_dist_07":"OSjRpmA35n1sP1x4mJEcgL8M","st_dist_08":"9DL59D21BMuVexjAzKt0GIOK","st_dist_09":"oSf1b4t1Zy6qwoSdr0eDsbz0","st_dist_10":"u8Melv0sZddrpeMOmk9oMBfP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"T9UidTUnPnX3Xk6woYTGNCEKrG7OT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1300,"st_w_id":1,"st_quantity":88,"st_dist_01":"FelSTLCn4RJ4QvwiwyK9mrPA","st_dist_02":"PaszdpGdxyvsjIBCBqQmoAQw","st_dist_03":"hKtvp8Fg78wzrocYK66Ibnw4","st_dist_04":"etlxBnagy9e0h31vrB2motFz","st_dist_05":"x9qH0wJIFqEyNevIc7tq87Sc","st_dist_06":"DbgEow8XWlktS9TxUs4dqWBV","st_dist_07":"7Od7I2I6g9mxkgFs8SBuWGPv","st_dist_08":"ffD00AVoJPrtPFu17LUIUay2","st_dist_09":"LWCGXvyBtQMnr3w8yJPGwrdu","st_dist_10":"ciSmZum1IqM6XMfUGwjMx5fj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3LoyX7xN3o8FRAP8LUGPw6PncKtyhZw1jJY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1301,"st_w_id":1,"st_quantity":25,"st_dist_01":"whPiVfYMkIQ8eUbphgJQTWAx","st_dist_02":"6KRYWsDVrKZQq3l2DhDX9XBp","st_dist_03":"51wqx4uYWcpe72Ol8k2CYgVK","st_dist_04":"bCTCTQXrd4h2R0YIuvVGrJ3i","st_dist_05":"ZlLHp9jMhvunH73eVplldzO2","st_dist_06":"HAzdS31PEtQ3sur4FQMXFspe","st_dist_07":"n7Dkvk12Xx3OJueRnnkrvh0w","st_dist_08":"n0kmJIiJwEqraPJrPGjugSba","st_dist_09":"YTUXHXHoJ7QZzyelZ3jP0ryw","st_dist_10":"cQHulm1xApRUl8xzxs5KqvJ3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"36pr0d2VvwTccF2lCTpWIJrGSfEpqTS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1302,"st_w_id":1,"st_quantity":87,"st_dist_01":"3dyJWOJ9PzA0rQJnv84vMasq","st_dist_02":"T3feXoI8koJyx1uNBfG63zYF","st_dist_03":"Lo2xSE989sRhZC2GatczSNL6","st_dist_04":"289iTLXoqShOy8Q2Tc33x4ZU","st_dist_05":"Hn1JeK0w8yhY6lv0CkRMQrhP","st_dist_06":"Yu8UtmQaTpEcxdt5ABZypWYK","st_dist_07":"9zxyFDSZXaEuebKGh5Piny41","st_dist_08":"CVUXIKGHIcEbRs3OOae6tgyV","st_dist_09":"1wqFc4BV1V3FhLSOr1rWHcuW","st_dist_10":"0clT8aAjdMBcWtIprmuFRpNT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xzmOjllMeW8ku47xpSuOxjryGuoG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1303,"st_w_id":1,"st_quantity":74,"st_dist_01":"HzvnoDGzwW7HfiFoc7f7RAeK","st_dist_02":"E9PAAKlJ6O3GWJm6rWMdkLBx","st_dist_03":"ckKlXKhCRecXWTPdqAbMpdCZ","st_dist_04":"ndp3kH3JHsv5IYAa6khgtDLV","st_dist_05":"PHbJCg3W0r10dkfPKI51i9od","st_dist_06":"qeD8V09D2YzjomltFHZA2gHu","st_dist_07":"glVSBYoYoTqchzHn4ELKAdQe","st_dist_08":"AOb0F29NLulPWOAfLv0ZJGtn","st_dist_09":"iWzPIQW82sH9hDOSr6UEBPSF","st_dist_10":"a5xbP0kGupWQB6BUaEV3eXcj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SY4NHRzfYSK4mAU44OG9qOy5NkycqKv7v5HsAh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1304,"st_w_id":1,"st_quantity":32,"st_dist_01":"VhXnU4RxeCZsNmiOW0IgjlT2","st_dist_02":"KuwhitCrSvGGJwDoo5NX1UWw","st_dist_03":"MN0R7YLtFIZAGfOy7Yow10sU","st_dist_04":"uSECPbcVA6RgQEuKgi2SBAQu","st_dist_05":"MG0FhnunZh3PZWynPCyZuJOb","st_dist_06":"HspKmgQbalpEnaGzF0tUGfAG","st_dist_07":"QPOI9dV5HcQUvOnh6VGSOnO5","st_dist_08":"7iHUDqqWrlO2OErMcWQnwJuL","st_dist_09":"plBYnBTQyN9jw1fI1FZRhtzP","st_dist_10":"NTyfCUQZhBeMvd46XYR9h6OU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RVBkCGoqbrMAGn3sQNmFh8NvLwMoO67FefvdXNbrZB1et"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1305,"st_w_id":1,"st_quantity":86,"st_dist_01":"LvcZmJMkRjdQYw9FXOmZBEbT","st_dist_02":"YODI6a81yQQG50xeFrwctgKe","st_dist_03":"nFeHW51wkao6zTklntdCB6pb","st_dist_04":"mnpRXOaTcPumfIhf2c74RSEC","st_dist_05":"7XlHWpuWg10Mt83glqrQCZrK","st_dist_06":"yqxFtEXsQu3XgTuzcrEAHU1c","st_dist_07":"iBdsABD9J7y64VGuU25kkOka","st_dist_08":"g6TKF3McbFdtwKPr3iuLPUcO","st_dist_09":"Vi05MBikqTw1DaBwsxbLPCOZ","st_dist_10":"jkjN0sIA6oP74KjUDXdCJ41u","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"tlvYA6nxryrLTbDm4Ob77ChBi35hiLAZBb9VM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1306,"st_w_id":1,"st_quantity":43,"st_dist_01":"5EbdQYqkuY1m4qPlJoHld3Kn","st_dist_02":"GGpvlIrIppa4vadDRNyd80FG","st_dist_03":"Gq4ijW0rMUhIbDLxD2OvSOFl","st_dist_04":"NREcmWE7hp9C4EXOL8U5adt0","st_dist_05":"kZZuQ9hwm6VsiNshySRk2Vbz","st_dist_06":"9XRfSUbvPoMwGCQ1iTFKDrYb","st_dist_07":"xCefN5BycC8dGjogmzjswoAB","st_dist_08":"jWSEtx9uNWTg2N7vcHnlBQJp","st_dist_09":"u5G3HyZWOkH6GyTZdOeOKwMd","st_dist_10":"7lLS2wVpXDYiYYgBZGuPDJt0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wZ40Gyn9xbGdG50pOJXZp4p9zwpze173HH1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1307,"st_w_id":1,"st_quantity":72,"st_dist_01":"83mPQ3XDp4oFYVXV5OEfCNz3","st_dist_02":"ZSnaug01tZntZB9SNKqX3ksQ","st_dist_03":"7c1Q4hfs5N0FYiFx6BRa6n9v","st_dist_04":"SpPwG2B297HXRQ10dU3QX5Rs","st_dist_05":"4RZfrLEFSZ363E8Ev1foumIq","st_dist_06":"bkYbHAdJXyuhuI15Ok69gz2F","st_dist_07":"y4QkeYL4X9hYtL5ChHaONvkn","st_dist_08":"5ur8TUhTjwoHAy2lgWusnT9U","st_dist_09":"1pJg7A7MCayowpsvRTAJPbNe","st_dist_10":"Xn0EbKPwP9yIkdgEdLNfSwkJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4BxzhQxy2NOhg6Qd8xNaAD8gxr7nVyo2GQsjZXTh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1308,"st_w_id":1,"st_quantity":96,"st_dist_01":"RjkrwCQSziE6ivTodD8PFQif","st_dist_02":"dGgsmWfw9pru4cIUWHY0k71N","st_dist_03":"P60TDQK7jRFqJwTuc0PEP5WM","st_dist_04":"97DXgN8ZoGoQvY8aHdNuBqU0","st_dist_05":"ZMbPcd9mUWit95viq5e7rHeq","st_dist_06":"5yHUWSFnyyDUINdD4HhqhetX","st_dist_07":"hQgioGP3ZkSIeSwxNcm3VTL9","st_dist_08":"6splcQTID7Z2PPprtxkBN4K9","st_dist_09":"Yuw5eFx0e06b7oqHTZQHmvT7","st_dist_10":"qsnSvQbzqKoQvYlwPJhXXDKV","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pYT7iKuq6x6bkWQOmsaZaOUFgUFS41w8YehYh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1309,"st_w_id":1,"st_quantity":85,"st_dist_01":"GpjrokqmCgqIRFFZtqiiBqF6","st_dist_02":"DN4elSD4aEFsnkWkNdBcnfy2","st_dist_03":"Bzz4Sg5UXNeWsDzuiCrYjG1O","st_dist_04":"AxYAFbKMpm5ayFN10gQ2TCwK","st_dist_05":"SfU9IpUPZPBxLAK4RrlGXvZ7","st_dist_06":"WLi3k5ZwCDheMa7Gff0kfAeM","st_dist_07":"ezY6wRihY873am9DQjl8F10E","st_dist_08":"9LqCvsXt9Bq8oi0EExmWDZF4","st_dist_09":"LOLzFZOT3p8gso929Lr7UkMX","st_dist_10":"Js0306MRSPZsdcEVO10KWdqF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bXp4ooriginalse2AYVmhIGgGfTD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1310,"st_w_id":1,"st_quantity":42,"st_dist_01":"w0RMYWZeu1sKiy0fHPcZJGsD","st_dist_02":"NutMoQuqxq9glvQihKyzVF3L","st_dist_03":"60ncStXyuXUdM0j9l9f0x2kG","st_dist_04":"SzkB00ZGztTHBu4NS9XamPHA","st_dist_05":"YxyckYecDAc1gVl7mbGeBrZX","st_dist_06":"ug378lW3Dsp256GKnIVNauuP","st_dist_07":"n3s2YZIypf9SixVA57p2AyBp","st_dist_08":"X2i0GFpMXBF5djVU07jRmzD1","st_dist_09":"JGbDsQOIx90ZkjfCBUeTyu3W","st_dist_10":"1oY67GKDFAP44j3dhfBtnbse","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4bSao9IoI4uEIP5tz9l8YFYCBtdstSxES5DPVU6UhAkkJScvyR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1311,"st_w_id":1,"st_quantity":63,"st_dist_01":"Gt395Gvl41IlT9nzzavhBF8P","st_dist_02":"qRNv2mt6lKDq58qrVt5TpMtr","st_dist_03":"pxGSNwrYZMr3AnPDVybplWcC","st_dist_04":"2Z6Y25vnzXvn6HqgBOLCCBbD","st_dist_05":"5wp8ynHUpbncvxk2CdIvjYqt","st_dist_06":"U0ao995UzJTBFNzCVczg3pcp","st_dist_07":"AlMnSsPuMUFLPj9kf9GIZyhK","st_dist_08":"LhxjOagPRcvPeEyhHWXubPAg","st_dist_09":"V9NfgvjbK46B3BBWeIiD8CHl","st_dist_10":"rmyd8rWsm6h8gIzKRhyJMDiK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"72esgzHF2NfMpk33L7FmPW37yqO8NVdQXsDHw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1312,"st_w_id":1,"st_quantity":41,"st_dist_01":"6Arz7P8veKLHDKKA8ieCkYxe","st_dist_02":"d3E0uWrIXCzmJ6SMSCthKzLr","st_dist_03":"Sl8C9M6CNkPEyGdUV7yTzkEt","st_dist_04":"Kg94CEgZb84k67Isyy41RSvu","st_dist_05":"P0NKWighdDMshBgYsWHaehak","st_dist_06":"2lEfcm3AxWguygoFOH97dd3c","st_dist_07":"NfJ61v5m62lqN4u05EpV9QRe","st_dist_08":"kYrsuo0jl6q0Tzv8ErT7P60q","st_dist_09":"vejj6qCPIa2aqJJYcc4xby5u","st_dist_10":"VjEOnVFPNyHdj5ToIfiYCkBZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Pfsr6R6k0CxGWe3evAZRifRMi8sj1smo5Z8"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1313,"st_w_id":1,"st_quantity":90,"st_dist_01":"JL6vKzByS0rFlNVAdThuDXgY","st_dist_02":"h6dsbykO1alvtQHTjYTNbiU2","st_dist_03":"ux8QjhbtVNDW79AfgKru8n1o","st_dist_04":"1RzoJlBXiGVxMfrAS6wG55Jg","st_dist_05":"5QQvv2w8FXOPUETRswVCh5Y4","st_dist_06":"MIpzRKl73KdA0DA2EunTYOsi","st_dist_07":"eAIrvhQyeXLeD6q5fuzJBScN","st_dist_08":"BuSt24u8C7SgfhTD9eqlIBVC","st_dist_09":"2GYbnTByuxmbW0r9ifO9hMIH","st_dist_10":"icdZlQdG1PGssfmK4EAPVdGt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YJ0PfgFh3oZ5ehDJIchPOY1981JFOj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1314,"st_w_id":1,"st_quantity":26,"st_dist_01":"yOQrIQTkzGyWLJ2LLhWV2x6d","st_dist_02":"ur2nWfBVYeP4EckqrusxMmRG","st_dist_03":"WYQM7YG6oIpfyiXdM5bi8c7j","st_dist_04":"kXmvGAsojCuicnV9lSeC16aa","st_dist_05":"1aJ7Zxis23mjkhRkVvXCDeQf","st_dist_06":"2Pa2YeCGl6oVCJP9qF3NBSzB","st_dist_07":"rCNvY5XL7sYwIf2k8xXqp3Dr","st_dist_08":"nMtDSD1j6rRXF2JNXwhaMTeP","st_dist_09":"rDFnMyrCYa76lMz6PNrtjZS6","st_dist_10":"h8sneJUMxFEy2k4DQqn3qDep","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"V38tYnOxUItoriginalABmLwdEiHGdDa6wH8SC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1315,"st_w_id":1,"st_quantity":69,"st_dist_01":"HYansfcADRwgPclZgYS0i4LS","st_dist_02":"hyx8yQVHmzcHSZDT1nGZmwPm","st_dist_03":"zOUhnRqlrDv4UnRCA5qdheM7","st_dist_04":"NBeDUsv7CWncWwcIfpAnj2l8","st_dist_05":"AHjgwf6zBoKjk0hFPvpcUFK0","st_dist_06":"boh9Dq2dz1YXwPjtPC9GJsgc","st_dist_07":"vQBDg92L0alN98wWE3isssWJ","st_dist_08":"5ycD42nV9sKIRiHJQWLdOl6j","st_dist_09":"gBjQmpWnEygDrDQAK6OCU0r4","st_dist_10":"uh7ZHaIaiz4yfFQ89FGkEKkE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jJerUwUXgMPSEeymyS0Y4uGlUiC1FBnXLeJfiuMZdfqjY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1316,"st_w_id":1,"st_quantity":14,"st_dist_01":"OKLXrckoVK066OKDFa5CbHDx","st_dist_02":"q3isuJNa4DJSzwlvYvg26ky3","st_dist_03":"5I1M2lWhCRbpvcwwZIkqWYeg","st_dist_04":"YZKViNXlcw7Gu9a7Pb24PdsF","st_dist_05":"BrX4ZNCI0NLLFRJRRzwY4glj","st_dist_06":"HUyoy8Yh9rF7BXHGvW1GpDSb","st_dist_07":"gVtBlJC76CyYcdemojDcF6bO","st_dist_08":"Zzr1ji8jg08MfMFNXOFc52zZ","st_dist_09":"VlN5tGrw5M5hre37Z9oknsan","st_dist_10":"5UQMxnywVHxlF5w7Lri6R6Xf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ixV87c3umf8qK7d10wzLhccz4dkVvlhlrX9tT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1317,"st_w_id":1,"st_quantity":58,"st_dist_01":"4p9adMrv1vaQ28htxhM1CDqj","st_dist_02":"3G9hA2hQS4CQhNbe2y3wraWM","st_dist_03":"WKaiIZpK85q4MwF2KKzdmFoE","st_dist_04":"8XnteAt4E11uFdNjGAbek6Ft","st_dist_05":"MeMzEfu1O9ST0npZ846qCtWs","st_dist_06":"FKeCCDm4Ji90PJkEBVDOOoV7","st_dist_07":"YjtHLgYnYjZxM91wlxzYloUf","st_dist_08":"v3UThWMELWVkbzknvvzCqXPz","st_dist_09":"xO6aSXGB7SY8h1BZur3GaZ2l","st_dist_10":"KVnUQK9L46ToYuUbTJ7NZkH3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"y5KkNWdewdfMrqvb9RQIN4y70HyPpZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1318,"st_w_id":1,"st_quantity":91,"st_dist_01":"kdXnzecq6ZuHF4tUlmsMtaRB","st_dist_02":"oaK7z7zab462TCCUZqeQN5T6","st_dist_03":"nb5zWRkPlE8OwU8juJ8Uefnh","st_dist_04":"eN0qSvnYBCdk1JHOxDViWg7I","st_dist_05":"oXnRiIP7cZnm9tsAOOEuMOde","st_dist_06":"tJabZ7sl47C2yeLSM9jRsD8c","st_dist_07":"8iyURuwkwjRlCND9JvCvgrd5","st_dist_08":"2uo5b1RAM22AcQUjUGzKvAT0","st_dist_09":"boarAvVxqXEEkjireBWclJle","st_dist_10":"eCXSWEfBptqVELmvhK1T5HwG","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"rXAm9nlgGGpdE6IR6yXbxwC6cpzJ7CgvxRqYZPaKVS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1319,"st_w_id":1,"st_quantity":98,"st_dist_01":"0MBkV8FKucXcBhkmenbE3G1I","st_dist_02":"HmYSfq6D5CPqY2YRCnbjWM2l","st_dist_03":"K2Og3bbXPTRwEwGmLbPm4ue9","st_dist_04":"Laxc40s9s74GVsuQWbXBBH2Y","st_dist_05":"RanbRl1Qo4QhiMVaNyB8FQYp","st_dist_06":"mFdP0STwl4XtomIsmAiuU2jz","st_dist_07":"RBKjQdiarXzi638EGWy6cz8y","st_dist_08":"Ni5M5ikae92lw82tSKk2r03N","st_dist_09":"MGgKJqNHCOPdAOLtuzDDbKnC","st_dist_10":"vlV3a2sGcENFhduR5NIlJtal","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9w1STZurDr63lxzxQUhW2YJmybYC05wErLMUnI7CXV"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1320,"st_w_id":1,"st_quantity":14,"st_dist_01":"30UQiYrafJbmTpUP6xrGHcyZ","st_dist_02":"8PFxIEjaUdfjmAWYeHFHfX3D","st_dist_03":"UE76yzPe5FQ8wxT2zP3mUwQv","st_dist_04":"Nqte63INMULPiFaiGTJEASu5","st_dist_05":"8z6vhPmxgMl1bH6utHzuyXYE","st_dist_06":"YSROBPpxxGe2nrhevLA2VgCR","st_dist_07":"E6hZafdUgTfDq7rieqFBiCq5","st_dist_08":"ijIqNFgVS0ntIZUZL1hWwH8Q","st_dist_09":"4hLTv7u5tFS6Yqi7j6LYFuVU","st_dist_10":"WCzaVQ3RQWDl3BvZjhzBQNLi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XEUZAjGwDINOmogL7llvoTaMDXUGgKoGZ8MU7VvMuRpo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1321,"st_w_id":1,"st_quantity":28,"st_dist_01":"448w2SUNWodL5RcoD8lypMvJ","st_dist_02":"0TE24krC9Uvlwr0aqkYf58KE","st_dist_03":"AnAHW2KDJUDMIDIHZ2seDTKi","st_dist_04":"SzTMENGT9IZywk0oCUTnxBuf","st_dist_05":"mkJxQY50tlyR0tmZnIgIvq7n","st_dist_06":"6zi7poiyEkrEsgGnNe80fj4f","st_dist_07":"lzw5UKi29rKa3Cmnk6NTEWZp","st_dist_08":"wHOTpcxKppx7y8NnXxPIvgC6","st_dist_09":"1vA4NvEbM4YZgkAvqIKQFjX8","st_dist_10":"5r3ZA1xqdVK1fXrrrHPFYbqh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NnUUGPymMHKWEpeg8TRPEVlYpSBOmIl3vigkIomubLf46YJe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1322,"st_w_id":1,"st_quantity":29,"st_dist_01":"JiWHOd41T6GEkGKPhJ0s27i3","st_dist_02":"kSuauclA9A9RuiMiESZZCAVj","st_dist_03":"4qWg3jb4ja62psLi5Dy9UYSk","st_dist_04":"hthBmuu3rjB5nJyTf95dgdec","st_dist_05":"MSZ08Swowkn07RhZ6tf760Gi","st_dist_06":"WptxCGQMjYtp79Tkqyg3hMHI","st_dist_07":"YqTbx4ooK9I85pa3GLY38lkb","st_dist_08":"WCZzd9NRx3VMglFn5ZJEdnoS","st_dist_09":"IdUleUrWRQpG8kT0YYaYGem9","st_dist_10":"rRgvOpGQbeyK3of0OASLnTiC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9HcW4dLLKjv43wtGUAq5nvNWMZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1323,"st_w_id":1,"st_quantity":78,"st_dist_01":"9bXGVuHXjDmQRZ7EwBVrIWtT","st_dist_02":"qHUBTFbBrnKzQ3WCMD6H4HJi","st_dist_03":"siR4V7HzHtPBhMiS1yVjVPuj","st_dist_04":"xD6RkIaznYMOOSMjWiSLJH4K","st_dist_05":"49T2oabRVqLYQ9UhMnhEjnj1","st_dist_06":"1aQUS1QrUhNmFob52o8bcBlK","st_dist_07":"bhp9t15utHDk5fEfSxAQbXkt","st_dist_08":"GJHYNxntiLLBhT19algJMG4Y","st_dist_09":"sCeq9LqhQix5ouR68IqpTeRo","st_dist_10":"2xokW5iUFiryq4u8WXPuZEHJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9qqjiSCrdpW1wlsNmA0UpKdl4FO9ogIbVDHL3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1324,"st_w_id":1,"st_quantity":74,"st_dist_01":"OtWNqGfzuLVLWGLLa6WxtWxJ","st_dist_02":"KSBAiokB0qsnzjcxZUirAPQo","st_dist_03":"SyPdI1Z3eqD7INZVZV3orMoc","st_dist_04":"7PqicXw8X6eisHzHZhGgIPV2","st_dist_05":"GJSieOD9A4y8ZsUyJZIxUHgB","st_dist_06":"D4jSX7isQzbcge8Q2b31zf0P","st_dist_07":"PYTEyqUTjKq2vdK91XWXWlhO","st_dist_08":"Xmx1fL5WCb7u812Xn7ohOal7","st_dist_09":"fcfVPL7oQOdoyDNC2I1n5bFO","st_dist_10":"lT1gqYo2FJOR8sQ9AAI5s0Bf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DR9nPkAx72cQUO2CfWWyotHbBvCQ2sU2J2u"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1325,"st_w_id":1,"st_quantity":57,"st_dist_01":"niC5dgK4BEvVRD09oQubAWHu","st_dist_02":"N61eHAVGVRXulwbC4kaqpbEv","st_dist_03":"IIrNi3WUP61bCqL2nDo2Jfjg","st_dist_04":"PBdPWZ3Zy4eezw4Upxqq40W3","st_dist_05":"M2E2klcFvaCZsf6NKx4X7aCj","st_dist_06":"ZvOKUKMwqM7tJOYDw14amNZZ","st_dist_07":"TAUHstRHgx6gbRtY5W5XCgYM","st_dist_08":"B38QLclro0VX5uRNU9sn8hHu","st_dist_09":"CKBQG6AicO3IH78E6srnDjfL","st_dist_10":"JqYhq4GpyhvnxqBwNVjWmEUE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lBpXcEA8vgfEHSMU8QSg67pNFxNYjLAcuP4dfIwx3P1b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1326,"st_w_id":1,"st_quantity":91,"st_dist_01":"n1ahlTF0spWSBYbPU7q59Iif","st_dist_02":"pKjXfzRN8lg103Kab9IXgPjg","st_dist_03":"hFOdbjYzUVcUtv37456W7ld2","st_dist_04":"8bfgxBFGyjJm3yib48MpqMpR","st_dist_05":"tOFl5KkiB7pKBqcGfSxKIpV3","st_dist_06":"gID0CFUv2kmEtijf2C473Jvw","st_dist_07":"WcHbD7GOTTjYi2hHRWSHBmou","st_dist_08":"vQ1uffqUc8gre4wGkRTJXzHN","st_dist_09":"fx3OubgyuO186IZi9aLYveAk","st_dist_10":"OAsqmC7C17SU8LJ29I6j02My","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"09W8E93QwelJQfI3gs8Wb04snQv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1327,"st_w_id":1,"st_quantity":54,"st_dist_01":"yI6GpavlF2Byq0hdTmsqBoec","st_dist_02":"agrEeeYxugSZkBxH2rJdV3oY","st_dist_03":"JNODd2TDr6TVfX48Coo7xiDS","st_dist_04":"ThD3ZKFoM0NqQThjY0zSSWDg","st_dist_05":"yksbrHNXXbyzxgOLMiRIYEAu","st_dist_06":"JWFtPPdHy1JA3kHSunF9ZIrs","st_dist_07":"VSGuq3NZig48DlULfaDwYCUE","st_dist_08":"BtiI88WGrIGkKs1nD4O6CZzb","st_dist_09":"wyAwFewFLKEbZ51dtC4aH0dl","st_dist_10":"EQIuhyM7vANb7CZWTh1kBnKS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O9Sjxwda9DL7dCx3SkuYCxo6WWzCdLQdfTiKeTv6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1328,"st_w_id":1,"st_quantity":34,"st_dist_01":"YKRhfUHEQPvqxL7nxFegQWHI","st_dist_02":"5q91mfpkhpEyvZpD5iurOAcI","st_dist_03":"KgK2k1QBN8r4WPamfhz367Sw","st_dist_04":"S3NHXWUqcpQQxJaheGv1Z5u8","st_dist_05":"fQCrkwOIQDmE8qQ9MUdNSwJe","st_dist_06":"7ggbwpLu7IIiCwIQrvKYjerY","st_dist_07":"ly3Qhx47gdg45GarDbYKoKmU","st_dist_08":"L5wuj89xkTY7BNfdLE3w8i6C","st_dist_09":"E1EulWZWCWIFyPyvXd6jACTV","st_dist_10":"l4Tk4GdtTVyV8iCHnUrT0pUk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fC1AsCBLFx2bhLVp2HOTETtSxNjfxTeY9qB4dt1SLaP0dIUG4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1329,"st_w_id":1,"st_quantity":51,"st_dist_01":"LkMW3IqOcwKs8u3x69ufD3mT","st_dist_02":"VsTpAsCq6NBCkPnNyfQJcZUS","st_dist_03":"NhqfICPQTVraQLy5tstUVFtZ","st_dist_04":"WSrm8yk4lAbuYMJ3BXRzftKi","st_dist_05":"QkWwuDa7myLrUNNZNNn3JU2x","st_dist_06":"Iyy7FqPFEg3tV985Vj3beJjZ","st_dist_07":"UfwxvtaiFEazcSriKQ4cYqAW","st_dist_08":"Zz8L6iux9BAkbjsiOcIrsmWA","st_dist_09":"5daojBSZ13TH7dcj7h60mNIY","st_dist_10":"dOoXpdDY7UnXBirLxjKhZHDr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GwHjjpRiojxtfmyqPD6KruQCy3tii7WLB99A"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1330,"st_w_id":1,"st_quantity":24,"st_dist_01":"J3h0UcffFDAYkHBZCC4Kg6XJ","st_dist_02":"FDpOthOjsYMSGB0GghmhHIXe","st_dist_03":"TUisvOae6TOwRhjnDxHnOhOg","st_dist_04":"5SMreXgUH0SZO7wBrgs1FZJO","st_dist_05":"52WKpjzTHs5rE1Puzoqyvvz8","st_dist_06":"N2PRClFCtLXMufRzFXDuFTPE","st_dist_07":"hhAY75J5atRU8ABU4x9cpAHv","st_dist_08":"Ka8CfuY03k8gkuVlhGYGeRoT","st_dist_09":"cKeDc1h5kLaiCVsd2Xj3uedn","st_dist_10":"I0XuT4igvZ6ysTOL5zhW8S2l","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zuBIg27ZsU4kohQFfVpwzXQ484H656k36oDBCY2I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1331,"st_w_id":1,"st_quantity":71,"st_dist_01":"Y35eKMjIBP3S9Aa6LXe329qD","st_dist_02":"UgDR3pQ3GGgjE6rEcectZIJl","st_dist_03":"YTwUnPKR1w41rPn6JQ8OwFmL","st_dist_04":"o708nfcxrHeh7M18J7iJeo8J","st_dist_05":"SeW0C0MnRAw0U3fKoFpYxs9Y","st_dist_06":"k2Uv4D3R5IgjlFLZxv1K1uEn","st_dist_07":"YeTs0djMrah2Q1YNNo5O36uA","st_dist_08":"a0OdwZSqxTstFTn38k9lVSkU","st_dist_09":"cdsf3rRsNuswbSLBdfkHg9xB","st_dist_10":"CRHZEls2TeILrzPwMYiutCXx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GYvHJxKIIR9WZKGz0CxBx0EkxUALlAwKdt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1332,"st_w_id":1,"st_quantity":34,"st_dist_01":"GqeDN14hpahYchY6OY4BMFMu","st_dist_02":"kgI3bQxhyi6AnEswgzqsrOYy","st_dist_03":"V8V5NsG9zMzT80QeqGgyMBR7","st_dist_04":"H4VWaF74QXESi7RNaeNI2HIM","st_dist_05":"vg7kLtbCaTSXYSG3C9QC8H3s","st_dist_06":"F7qttv5yrsc23pGSw7Qm9xG0","st_dist_07":"zKb7rDbkpiRv5xnYtdBpEBJW","st_dist_08":"IIU8hNmofjIETW1P5wr9gFB7","st_dist_09":"0e73hAnlOYx4ShwOaDQk7Mph","st_dist_10":"9UslqUSCYycndjbXy748WrwL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vOmuQHwrJJnZr5qbrX0maNsVe3rwErA05HWAbVW3UyaC8VyB2s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1333,"st_w_id":1,"st_quantity":51,"st_dist_01":"A1aGzukFfoIU4nzQAovFtAXX","st_dist_02":"JiMYWVnwQvynzn0cx8lzBQTJ","st_dist_03":"NNcLvzEgpyZMKTFSgzwARm3r","st_dist_04":"9UKJAD6qNjvoLaOZxVqhtg0f","st_dist_05":"MH6Ogw7buyVhBFlAcgBP5xt7","st_dist_06":"W1Pp5xpKtsF7lzxI1OgpH5Kk","st_dist_07":"OPyNpiEchzCp8my2V92nIsJ7","st_dist_08":"LBOz7XsTyRCRKCqGyOdU8Wnk","st_dist_09":"Rru5vK9wHrOEL36IdskARMtP","st_dist_10":"6Ndml7SabMzYz65xeKaaDCVT","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"u501sG59cNCKMP2Ygbf7vDc8OLtYwYcH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1334,"st_w_id":1,"st_quantity":58,"st_dist_01":"l5kgURh3Dj3AkmfWKc7XF0ZQ","st_dist_02":"ltPgsg4MuuCXASOkFBr8KD0Q","st_dist_03":"FGsK2euMULCQ8RThVjXcX8z0","st_dist_04":"8RzgR3Uj9ybA8p3QMI1PxevT","st_dist_05":"TcEJoRo3SFuHYLSRsRq1gJZ1","st_dist_06":"ZtGD4xddJLesY35iSOWvHJuc","st_dist_07":"ydO2BwzQvVS6DojnFsxqoc1x","st_dist_08":"Y0cRmAYYWyMdK7paNyrzeKQ1","st_dist_09":"XYt31g389fyz8HuNS4yoxcQv","st_dist_10":"7udpjqIQUGrPgL1GkbeyjskI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cZzJRjY3faxhxlFIceVWUfrWL4FlVa4gicrK59wOt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1335,"st_w_id":1,"st_quantity":97,"st_dist_01":"HpcKqQykdFeSNrTZbfdWm6QF","st_dist_02":"VfxynNFvbLylQOhH3UphjElK","st_dist_03":"02hYsgZxo4b2822ZeGd9SXoX","st_dist_04":"9k5kR2Pcr29dMfkV7PxWB9Lt","st_dist_05":"fqBaOJaKgvV91L8zEu7uWLK2","st_dist_06":"zaOaSJpNR9c52FJZGvte3aMN","st_dist_07":"n48Uv4tlnWiNswDxd8UzCyLL","st_dist_08":"WuWroi29bYCp8JfCVMweCOvL","st_dist_09":"nyHZUccprdWEARMaxEjlMDyW","st_dist_10":"4KBrFGcNzPf1zC8gvisAzvxj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"V4KCZY5AMylW3H9RFehPhkg1tfByt0yzqYQF9w76EkLKKEnqYW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1336,"st_w_id":1,"st_quantity":67,"st_dist_01":"nCmxIx8jvUAtw1mKbSj2y4Tt","st_dist_02":"pkSnvXTQsQfFFHP907WtJ6tI","st_dist_03":"7niemiaMKWS66sQTuh1c1AM8","st_dist_04":"GgpdKMlllfbiwe3iAhpwduPu","st_dist_05":"wxKonMVgdhaypLyb2BYP8DJ3","st_dist_06":"VKoFp2M34Ew8xhLzEgdQLhmB","st_dist_07":"89oeNsN1X4hDhSpovXAKXjvW","st_dist_08":"UONu3O3KJ0M2c1FdCU07XOxX","st_dist_09":"7nJ4NezyPHKeQF8uOMMzuISK","st_dist_10":"V63ccux7D4G4WJkiFWmW7VXU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"O8QMlmOqoSEV5v5Yi9CAythzpM4BpAQBoCSDx7vZGVr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1337,"st_w_id":1,"st_quantity":49,"st_dist_01":"jTFuaHjOznSB8PEGRhlcM1Ec","st_dist_02":"cHnJhkhXk5hWD47BR0LmDnT0","st_dist_03":"I1smx3iicGFsrHRVamd4MrdN","st_dist_04":"FTiQCXkMwpac7hMshKugRFwa","st_dist_05":"tImVC9yV1eUR2dskmoClXZw5","st_dist_06":"J5mUaQOVCL0EsIkoq1JzzRL3","st_dist_07":"FjYoJBV6dzgz6ROom1fTGN7D","st_dist_08":"4tJ9JfFBiMGpQ5J9UQIwZ9RB","st_dist_09":"p7yv2JqKvT3uk4PzD50DvjiO","st_dist_10":"1MloqKv3AnXSrgt4LJOk9U3X","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xS32ux3SQ3bIXPYIib6c18eq8qOJit5pnPU4F4lJcg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1338,"st_w_id":1,"st_quantity":73,"st_dist_01":"YDpg1Xw1BxJmQ3JyOGWKxPTp","st_dist_02":"h1YvJLmElOdL6iOy56FcAC8W","st_dist_03":"jUwpZq5TRcK4kANYqcxzqD4D","st_dist_04":"dxVdKDdd7Zu4vgmfp7LY5PjO","st_dist_05":"IGGsKcK0RTLNYKmaDdVpBZ6t","st_dist_06":"VBG7QnsInk3l2JS1TjZ1wqB1","st_dist_07":"nxF2NIhoEI0bwW3pTvzqfbZ9","st_dist_08":"ceXpT7uUbYiTxRYGY2lZtVLN","st_dist_09":"TDoKgxSMKg7DYoUK60ueTmo9","st_dist_10":"HQc5Ij0mBdKRxXvQjwfIUXvv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Wq5OXZQJNlQ2fv84qBp0Z1n9Iisz7mYyr8kmLaBE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1339,"st_w_id":1,"st_quantity":92,"st_dist_01":"mfJpfSk5nFhkZ97CBTDPU4hX","st_dist_02":"3IxPOgJ9obeGPmuZYgjA8ZcE","st_dist_03":"nHWnyVdfhxlCHVi7lcOKLZx2","st_dist_04":"JSRwPTEpD4dctYhY1MQu8J6o","st_dist_05":"AMpTYHQVQyw1J9kCb2IZiSyl","st_dist_06":"pRViHP3JpWrOQIoImM29ULyu","st_dist_07":"7QRqzPUOg7mninVTEv5791xq","st_dist_08":"MOxbsk7B1tpZmtPCCzZSsyYk","st_dist_09":"LVBe1aiA6b0OlTgMS2LRoVTK","st_dist_10":"JX1763LpUx5SgczQCuCB4dqP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"1D05yQruDuhoriginalU4EyrbEVm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1340,"st_w_id":1,"st_quantity":60,"st_dist_01":"iv0qEd6DqcKh4CCC3A2ZQ0zI","st_dist_02":"ZvAAkANjXF6ZyOrbZERGYdLS","st_dist_03":"XuX0c02hYjqTx0LfJVfCuqnA","st_dist_04":"44SFlEhsjNRgZ9U8D7bJDGpW","st_dist_05":"PdaP1Tn3QG5Qx4XjFApYgjSa","st_dist_06":"2Dlz6UA3tk0FuLB9hwhMnNtJ","st_dist_07":"uAqwFllSMdN44hq48FItA3W9","st_dist_08":"bJ9TbX1X0WbQNgI1zcOfnOeC","st_dist_09":"uP0Ogw7WdwF5Ck6ByMfeA4DN","st_dist_10":"pDQEkbo2nwRYahz9LptD07ds","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Vz5IRr4LpY119fPfl4vpY9u1OaCig9czENZ9a"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1341,"st_w_id":1,"st_quantity":46,"st_dist_01":"x32Dfz4R96EONKPvSmW1ON43","st_dist_02":"KVu3DL2w9kspm2uj0vB8trak","st_dist_03":"j5N1VpnMiMEx15hVpQPa1d5w","st_dist_04":"f1iOWENkgFBodfJZi5e8eMid","st_dist_05":"vBKFwQdJkBtIndoMmzekgsJE","st_dist_06":"z52UNEhPnFeopLS4IKFB1j6k","st_dist_07":"wkLeyqaTAF9bvhaBANQQq3Y4","st_dist_08":"QA8sOnm0NPXC2YGPw2vZxWiT","st_dist_09":"YdhCpkOoGhkTkAuOsV5mAsVY","st_dist_10":"kpFpAKZDsEOMvpflTuvlvqGo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wNjmjbRWbpTCjcuOpQ5WGTcwWc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1342,"st_w_id":1,"st_quantity":88,"st_dist_01":"oxZvqPrLaPrqbhiybvvHfLwx","st_dist_02":"T5MT6TQ4IT8h789Ff8lof51n","st_dist_03":"VHu5VsnxDZu43wg750CMvym7","st_dist_04":"4NTLYTfwdkoZuT9JN4i1dvma","st_dist_05":"lSRcuyKiQ6nz8aYJ1Q32mH9O","st_dist_06":"1zQfzYmLVlgwm8sY255u4690","st_dist_07":"NeVrvQ0WxmBh098BLMzeYMkL","st_dist_08":"7Agn5UMOhH2AMBdDPD3f1LZU","st_dist_09":"00qvpHSEWRJGNZlUMeXiGE8m","st_dist_10":"2jPZPnUWZWuQHjLy7FoSPtvi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"OYuFfNOPWMm634klRccHlwzpJ7mYn9p5pblHky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1343,"st_w_id":1,"st_quantity":93,"st_dist_01":"zzlDdWbadudhQqJrjBEVmulX","st_dist_02":"GfLgSDdlh8q05c5I0er7I5Gb","st_dist_03":"1lJbDBevjUv6EtnPr6yIsFN7","st_dist_04":"SbnvWe59xyfml2uuRswoYZ6R","st_dist_05":"yMLSCS7KZL0z7NTLottE4hRW","st_dist_06":"sjdc5IwZOkRuM2gQ93gUu64F","st_dist_07":"g5MplV2qlrITMOGqGHcuCt1V","st_dist_08":"7Bz66BkkjmzHHh9GVFUQd0gR","st_dist_09":"rjpYQFg0T15fFH2lcTkJlja6","st_dist_10":"l8Nar7446GX0BCtGG2dfEAmI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FOF48XgqOC96zBIUEAmcmPB8eBz2sGsd8AgQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1344,"st_w_id":1,"st_quantity":76,"st_dist_01":"NBQM8G35nKiYKrhwe7zjI8h6","st_dist_02":"PEyBMZpZ7zKPq8OvhLzbyd0Z","st_dist_03":"bq5RnpgIzuqV5UCaPHwYMiyS","st_dist_04":"OVTISeRULAvIDJyFS7Rwcm2R","st_dist_05":"3SgG5l7corrQKzXBsZydNWLn","st_dist_06":"PHwQDCz5xLbePD9iW8SZvklH","st_dist_07":"E51iokOX3OCM4tjacyrk3LKK","st_dist_08":"ZR9mWy6elJBv6XDCDb0VjwQd","st_dist_09":"1g5QGlw3H92tRdrfcfmVtfRa","st_dist_10":"Xr2nDbD1bi26GxBTwHStYoQu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4uACGKPYZkYRMTSe8pgFoX9YUQmuF4gru8u"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1345,"st_w_id":1,"st_quantity":42,"st_dist_01":"EcAplvYrYpIhXQnC5VjJj8h6","st_dist_02":"sEOm4az2GDMQ4TpKrbVRZHzX","st_dist_03":"KYwyNGArE6lHCKb2EoHDOHkH","st_dist_04":"aefiBeV4wI1tAlmsSpBZ9ztj","st_dist_05":"AveQ2kgQAxILk7AtuNzIOoGo","st_dist_06":"gauPP8BmVU83ud8LIY17IgMc","st_dist_07":"koAStENZBCVSFrY4cMF3xUb7","st_dist_08":"rtt9Qqt3CYt3B6uyMHSBElr9","st_dist_09":"fwRBNol7l2CFLCRCE0aAnDyn","st_dist_10":"l8eErVG4tIPtBW5Yamm8KaOS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2mbXUDdomgeJ8WLHOt9RDd5iy4ha3LW981i9FCaYsOa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1346,"st_w_id":1,"st_quantity":33,"st_dist_01":"tf3Js8Jqeb1qNw8zdFWpURXb","st_dist_02":"b9vW1LEFmVQQoVRYBAyGSAUu","st_dist_03":"AJn1QMdWN4biNT3SK9cK7Tnw","st_dist_04":"TaBuLyESWBmInqJYrm2wxCC2","st_dist_05":"TRraPr8fk6FNTbn0L40IxCGJ","st_dist_06":"K8KhJhhbSeogKV7Ne0cZPiQv","st_dist_07":"ba9xUvOiXhVWt2p0HZ23y7Kd","st_dist_08":"rUcNk5oNnZHjY9wP1M6ZQRgl","st_dist_09":"AmgxUWcwQrxODg4JiBwxcj6A","st_dist_10":"qvTUgnMAzFfKOK9VFHXexoiu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uqrHnJEPNbj0Ataa5libLXNDwIxQBHbja"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1347,"st_w_id":1,"st_quantity":20,"st_dist_01":"HI5qVwNi4XQg5mzyTusqoiJP","st_dist_02":"L5L28oV9uj5aTPpYonaUSBRv","st_dist_03":"FU8svd3jpxdoWXG6aoqHPKD4","st_dist_04":"3OsYbsMmqyVm7pK7tIiFn8PM","st_dist_05":"p0DFnISGg8XrSuHAGBBcFeMq","st_dist_06":"bLuJfL86Tdd5NhNUMCxxZrrJ","st_dist_07":"SNNKzeARnSDbFw9oeKeXe2G6","st_dist_08":"TyMY3eaCggAOOpV30mt7wxcC","st_dist_09":"GRF7XeTwS7hDLq22qaWrMysg","st_dist_10":"JYJzDuGBH6hNIOERuJFWy7ov","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Loh5NYZLIClZwz6kigh6VYfunRTlFRtEBK0fUyDSai"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1348,"st_w_id":1,"st_quantity":52,"st_dist_01":"GRljHBjGH3jXFc5VhN1tXmIY","st_dist_02":"YCrJHMu8WxxNZzZXCGzyVP7J","st_dist_03":"YCFZOFiNvAB2lKlsHeZVmC7Z","st_dist_04":"sCWkDHdC6mNG1aoDhbRG9eDo","st_dist_05":"9ElsOv6oezHi2BhQ6mx1z0QA","st_dist_06":"Fkwaj741geMB6bAsQAct6q7x","st_dist_07":"fCJX2VGI02YbDlYzZZBIrmyV","st_dist_08":"pHKagYCfyMry3wgKppVlVniE","st_dist_09":"pROwETP4v5TJi9WJDMOkTxCP","st_dist_10":"hMFEbmrAwPz6gaAw5UJbqRD0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3originals05Nk7VrhQRL7yjmnZUNawRbbmO1UfI1YUz5MYB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1349,"st_w_id":1,"st_quantity":21,"st_dist_01":"PGRROXlzOu4MCm7Mkz6unEHz","st_dist_02":"BmewJwZnaPtCQTaz7iNnZJ1B","st_dist_03":"2ZviQ5ooSapMF0iL8Uk8JMCD","st_dist_04":"GObvP4IgU6VouosLatE1i2GZ","st_dist_05":"5DhaOFIRvqyowx4GL9OnKkfN","st_dist_06":"PNPF3iAvmLMHwbSsC0rRqbrN","st_dist_07":"2Qqy4jYY0oA4S2qCpbAlMkNY","st_dist_08":"6nfub2wvFHwA0sHVQtIEZDt4","st_dist_09":"tJyV0Mg1CV6bj9aVf3isHXLR","st_dist_10":"NpIDPJcEW7oPHwJBl13LbGcI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QCvvZLH7gTL62i8UWmFkluAlEeVr6Kzg3GCEc9VLaRug"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1350,"st_w_id":1,"st_quantity":73,"st_dist_01":"lIom4mm5MNsj1GkxuTAhRPFV","st_dist_02":"FJZ6A9CFl1Vp4iWHOeDx7q4K","st_dist_03":"ObcjAy9mQ2fr98SmMiT0E88m","st_dist_04":"SpSLEpV9I9QqPauiYvno0pWK","st_dist_05":"qhgJtJQUXdo34iMZmQroRbZk","st_dist_06":"O9hNKJGyy2eHYhQL0RMIuD9n","st_dist_07":"WZ41LbiNjRipgCY8ytr2F8P6","st_dist_08":"z24gkLgXVgaN0L1wxgIL0mpW","st_dist_09":"wgqRv0p0ZajbvvTU2HInGjlo","st_dist_10":"5phx4zKZI8AGiQar2ib5riKW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lo80hA6O6Hy2Hc4WxAsItlvXS7F8QrCbuZSwyHPzD4Au"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1351,"st_w_id":1,"st_quantity":24,"st_dist_01":"il1Sb49o9PfK6St0a4FP5rMy","st_dist_02":"5n8bOaGJk7zdA1Aox84TtNNf","st_dist_03":"L6zhLIt2NDDMt4nbvgCeVfk4","st_dist_04":"oBSK0uEJyBuaN3jnjN6J4qY1","st_dist_05":"R1gfMRXx5ZuvEIEUPr6kpSOk","st_dist_06":"Y7n0s4eLqfmVuMfLCk0wCT31","st_dist_07":"GubavgFxsK9jx2vxbQroBGdd","st_dist_08":"7IpX9jlxOmHpJJ9i97yp5oWa","st_dist_09":"3Xxbw9HyjkBHubG0b849LY1d","st_dist_10":"5x4f57heXhJ3QNMen6AAX50Z","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fcvbRpL6WIJ0B4ta6wkMUcQXLYCdYE0aPDNugaI8tD6V7LN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1352,"st_w_id":1,"st_quantity":42,"st_dist_01":"dzz3hOYpAvdAPNTeqN4RiLra","st_dist_02":"N9TsOUN7reNPggDiccbNcnqM","st_dist_03":"ve9Of6zkDr5Xad3jfRDNHskR","st_dist_04":"6fQ0ye2A1meETEqtwSfoNsI7","st_dist_05":"8tIaz0bvBV5Eb1BocC1vm2LT","st_dist_06":"foJPRYKOHtZnytg67HXdU7ay","st_dist_07":"b585sqpiLmAaeLPOito6CmoR","st_dist_08":"vdfLUpkx5ArEIpgG3s7RUIvo","st_dist_09":"lGacwEtiCLwLUkuBvrgtHaqM","st_dist_10":"mGRCn7u9fZsaldV1HPTqUWIJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Wvki0bH5h2oc6dOqLOiCDLRIpji"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1353,"st_w_id":1,"st_quantity":88,"st_dist_01":"3pkST5WkTnWzgorSnfKqQq6G","st_dist_02":"xpzwdrx4py31RiHaRzdIlx1G","st_dist_03":"9XNZpU1sVgs1n28gcZclNdQq","st_dist_04":"GMLPqDegHss8TcmCBgLMC4lk","st_dist_05":"7r899IuknhhtR0RHXQEyshWA","st_dist_06":"Cdzu3yS393QczaREwtBOLn7c","st_dist_07":"ZmqemUGbGqEAOjoDkqIvNtOn","st_dist_08":"xiqrT3yggQfpS6fN7g90HbpQ","st_dist_09":"hVCfeRU9DPa5J73m8CXIVhbT","st_dist_10":"nGlnt2304ncNIl9azfIaGiKP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WEAxp125UksVvgYFhPNO4MncalztPxeMBh9XEu8zxpvMz7U74"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1354,"st_w_id":1,"st_quantity":60,"st_dist_01":"NDROzKl88yZmHEsMfbenSbQI","st_dist_02":"fV7yy2zkPzdwYv5zNUmVrGWw","st_dist_03":"XV0VzGYZCpoI6laqBNXelnMK","st_dist_04":"irLDnd28VADhDEnjM4k5OCWO","st_dist_05":"5kVZtXQ2Qx5xjCuD6frN8KU3","st_dist_06":"PwKputcl6bLxs0kB1N74fjLT","st_dist_07":"GqtoY8CA18q7RJisqyg12pmR","st_dist_08":"vdjQjH4lWTa6jBPEMeHv0Hz9","st_dist_09":"UYnJh0Xk9Vntpe14YQ3EnJBh","st_dist_10":"fitLiAVJnT06oAiuZ9U99QUy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JZAbYerk8C6MTzkhDzIzfoOz8l9xN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1355,"st_w_id":1,"st_quantity":73,"st_dist_01":"mvCH5PvaPyLRG0PCDKw3IsF1","st_dist_02":"AqWdD4wijzgYlKUEfuYUB4M5","st_dist_03":"CZPthJQxhaMsXVkQRufzmWAq","st_dist_04":"2E8waRQd1XZ68kiwdmqlxsDG","st_dist_05":"4AepezMmZfopQu7Rfzs4Rh4E","st_dist_06":"lp3tJtlEN8038E9rNOi2J5nk","st_dist_07":"kRcasxTkL4hMXmKZoMQz2bOB","st_dist_08":"AvkH70fMANNoxf2vIyvJ0s70","st_dist_09":"jToBPRPK4aa8hTqIw32sNbEE","st_dist_10":"NcQbYIzEnNp1G4TVwNtR1thc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nEXfgP1CFA9RofzWCplq5CZ5sgnUmGGwO5bIcYYO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1356,"st_w_id":1,"st_quantity":63,"st_dist_01":"RsHeONh7HWHSbyzsJOK0MDZV","st_dist_02":"HXczScbjHuAygzzLbu6gIwKF","st_dist_03":"eoAAm9ffyewpisD0aH07bBJs","st_dist_04":"x1EeJWuUhPtA0dUB1SYpkjij","st_dist_05":"isT3FUXmmDqtJ7HxaI22MWSh","st_dist_06":"yeKuYbOGj0PgDpTwG6DLzXa2","st_dist_07":"g8GHRgUIH1LwH9OrvjLNpIMk","st_dist_08":"OFPLBDK86ekXlcwPVDDKSTdV","st_dist_09":"tkmhZIxjymzWU3yuliOfJvcE","st_dist_10":"3bwe5ucw9f9Grrv3mQvkiCUg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Pf0rgAMAc02Gs7HquoPhatUHlp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1357,"st_w_id":1,"st_quantity":30,"st_dist_01":"EsYqGCEst33GYUwftekZnxSt","st_dist_02":"yZy7N312ysyg9JXuMWeqxM3F","st_dist_03":"6ljgJHMBT4m6WYUtUVLOROg8","st_dist_04":"5VeYc5r3UHN0UTyI8wid7JRE","st_dist_05":"JIvdUaIexMv6crGkmchH9Xhk","st_dist_06":"SJarCvLbKV5d8ca7kuiRdrJ9","st_dist_07":"NQk76jOywZzpHCkK40HykMI5","st_dist_08":"XYMXyPcxpnvP1NWy9xgXm7QP","st_dist_09":"sEwfIImRMNoNzBUr52NWMFzc","st_dist_10":"oqFeNIqZ0q0qR9OeWxZH9lqR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"uWDnwbCpxQAVgwnykGSVO0WlRLnaQbBNadVOa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1358,"st_w_id":1,"st_quantity":41,"st_dist_01":"bUzrHHb7L0Cs0vCjDRJHIpRZ","st_dist_02":"0vC2B277jKxw9P1wRk88QM1b","st_dist_03":"UeJHId1qdBtDrIDcwskL8pfF","st_dist_04":"P6Ph29jvUTLCkalOv6GgdNmA","st_dist_05":"g31Pcwob5u48MmYw66FWUCs3","st_dist_06":"SrraSOH10YvywvehP9fjFDQj","st_dist_07":"tx9EmhlnsvpHHMJr9TXo6iX5","st_dist_08":"0JE21JzcMlSlnxDXdov8I82W","st_dist_09":"v4fxjHb14UqZMoG6wpc8uVqy","st_dist_10":"QjPZpqMXAlK7QOznbioovrJZ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fAJDfqf2Z38RoXsJchxrBitja3aKi25JQmV3KSE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1359,"st_w_id":1,"st_quantity":87,"st_dist_01":"bR4dRMV4mTfWGcZT27aFKk7E","st_dist_02":"5qNhf31svnAWcDaBirzLAkeh","st_dist_03":"4IvU7kDOWoEfdjVnmVhpwhRR","st_dist_04":"WLcZYKihhmSAjoXdrXTqh3an","st_dist_05":"ufuALGAWjngEwaft0Uru1E7u","st_dist_06":"pIM61y2aI7uELbeFxb6v5PG5","st_dist_07":"YAWW21TLH7o8Lh5sxP3z806M","st_dist_08":"buEDDgihLZv7hrIOxuJW9p5u","st_dist_09":"Apbk3qUv60eKl6ifRpBt7mdX","st_dist_10":"8HDXl7Du1zlHn8rHeCukIMfL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0oWpfTBG2ilQyLgCIUtPzenIGkIK6sNcMtH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1360,"st_w_id":1,"st_quantity":44,"st_dist_01":"480f0eb6GCPzdVNsHK3untSw","st_dist_02":"tAaVkI8FX2VK2RJ1vlwphWsg","st_dist_03":"4yA84fnEESmq1W5D1MtKbztw","st_dist_04":"rusAx35WWZvFqXBwTkVaseQ5","st_dist_05":"O2oWV8dDZqedeSanmn6Vmdjv","st_dist_06":"0pdnnbcSDcqbcAeVuuMFHQVr","st_dist_07":"pkbw7txRi8yQYJ7OYfDI5x54","st_dist_08":"I3qX8jyE2WNIy4uqK1ROygVb","st_dist_09":"sDZnJaIRqbnBRlVF4ipEbiof","st_dist_10":"bB5xf43MBcam6oaR7TZ3A5Ty","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6G94oZdAW5vGk5dJvMTvNlfoMEa0cll9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1361,"st_w_id":1,"st_quantity":26,"st_dist_01":"h4nAhfc64iRDMK4qGofCiGr5","st_dist_02":"MGpDblzHXi9yHzjp8DMIAyhW","st_dist_03":"PlCBSanqvjdeDDS0QAcRApvk","st_dist_04":"yFysjK75dn6wyherQYZzJYgW","st_dist_05":"tRiKDo73K9PpG26imNyZGRxM","st_dist_06":"FICJwwmGGBkL6RKWLv1WeUG6","st_dist_07":"fTzZozYoPkc7m8tatQm816mV","st_dist_08":"6Re9MIKev3Uk2PS0luF9YKZm","st_dist_09":"w3usmCp13ZUn0UloGavzyLv0","st_dist_10":"1P46VfluSvwA6vpeQLJ3ma7y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"V6t39gqjmWfxpIiVuywpqtFEfj"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1362,"st_w_id":1,"st_quantity":22,"st_dist_01":"aAo9CXnKTYuXIhCgFTzL93eC","st_dist_02":"uPmLOhHemePnrFgvSRB92ou3","st_dist_03":"w2BxSEULm2Nf5CcLtf4rB3gF","st_dist_04":"UutU1Bh92G3YAOs9HuLxkHOL","st_dist_05":"LmhNiEuV4IHcbxCm8CYvarnS","st_dist_06":"HE0iGLra9dY9PN9OQDZe5rNt","st_dist_07":"DlKArEcEbikNnVUs5nMM7B6Q","st_dist_08":"8kVg5TEMxdEUaxNEzXBXkdkh","st_dist_09":"ygZFYlFh86wuMoLBZgCEuF8j","st_dist_10":"oZBX5tXG6D5wHBaHURF14zf3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PEHwmnmUq9QOY4mJXXYuQbdQvIVrJ2MtZIl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1363,"st_w_id":1,"st_quantity":39,"st_dist_01":"GQ9eee9MOQJQddqEXVN7DYXG","st_dist_02":"fRWLbFuRWYjYooUosOMJxAnl","st_dist_03":"DEGeKkdzXMN0ciBhs9UI7HzU","st_dist_04":"WIOZhTCQ3wWJs4Bqq2TrtUxd","st_dist_05":"ynGRHbJL2UadM9p2Ig47Bu9f","st_dist_06":"Ftzjxmd2DP61EAHqxsYILltI","st_dist_07":"MqV2jjt7ZHlgDbySbSA4O5N4","st_dist_08":"NIJhJ2ay2OF5PS6oLGbk5yJL","st_dist_09":"m2oJoGrnB9ai7FGgwhJwGOIB","st_dist_10":"Zwl1puPRPJSiMbfwL6SVeVBL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"weQlyH2UmDnLsYLsF5CXcbpfHT67Xm2woGqpyKikdqdCVi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1364,"st_w_id":1,"st_quantity":20,"st_dist_01":"BO3k6CXN9Qxmg8DS87KIr2rF","st_dist_02":"n2tcUSsNYlBeGYYr7P9ndehd","st_dist_03":"XNagMoF42NwtvgjVJ9bMPwHW","st_dist_04":"O6vlnWir71fGbiHolrWTpGw0","st_dist_05":"99TWDyPhy8sT2R8dFecr1rbD","st_dist_06":"ecPrJ1WaSmQbftOdxJrkw0AL","st_dist_07":"e0ryOhIubE4qI4rdNIA8tTfd","st_dist_08":"zPCMeMyzZfqHMTNftRLJaL1f","st_dist_09":"E9N0rdh1ksv6eILllSABtYqY","st_dist_10":"xi4rxlRqpVNKvpU7RDLgNIsj","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SCUUJ3TvcOc5eVuiN6rdTkYYIWDyYU24originalCq"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1365,"st_w_id":1,"st_quantity":25,"st_dist_01":"0FuJoRt2d9fwPmtl26kK6zFU","st_dist_02":"X517mdUpRZwkbzTSpizo1RMl","st_dist_03":"ixGqnVUALlyuPjh7jnzWtjxB","st_dist_04":"XzVTTS0qsn0K1hbWOwXYiHSq","st_dist_05":"U4VK5EUG2TtCKLOcJXaHLEo6","st_dist_06":"d8qww12hOFBCy7SIXOGbHI2p","st_dist_07":"LaeKbqwPDcdIx0BJzQTHYkVj","st_dist_08":"dRK3lYYYg0cFW4koLcu3jLZ3","st_dist_09":"fer5VmwxVpR6CZ6PmuliiRq9","st_dist_10":"zaPChZKkAWwhuRo71ipSHJgH","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ypzSV4YBaEKoriginallE5NiKvclSnVAQqMy6yM71rbs3UhXHC"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1366,"st_w_id":1,"st_quantity":55,"st_dist_01":"D4AyZfqfUPEFHPEsBYKNT0SX","st_dist_02":"Lrz10fp4D3FVKa8wnKjVZ44b","st_dist_03":"HIF9n2w9Oe5YCrnyC57idBpQ","st_dist_04":"CroXfK4K6BEZC8PpezLycpni","st_dist_05":"iS0aFcNYUG9eShgHM4By1zFc","st_dist_06":"NIU2kIs7E2O4akYRu9hEzp3k","st_dist_07":"MfW8TurDt9KgWI2eXrde99T0","st_dist_08":"xr84aHtfPgsMsOIIke9cn7ba","st_dist_09":"lgUEN1uOxTMppBD8hBSczyIj","st_dist_10":"R4iW7qz5tY6fJuPFO69bT7K4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"22FQLJYTnu16feBsgjP1X4wkzoqOBPE2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1367,"st_w_id":1,"st_quantity":81,"st_dist_01":"EFuzpyrDrM78AxsQEc9W2oDN","st_dist_02":"wT1rFuTMGbhY8Rq7y6VVioeO","st_dist_03":"3Qr5teiJXIFZHOZsd0KwuL1e","st_dist_04":"n7IbNTNuGtJSuMRc3wqmv1hC","st_dist_05":"fxj6EjjtCrzawGUkJt0N355i","st_dist_06":"2DJVPyOPxOgEP2UHfxO6Pi40","st_dist_07":"wSi23f1k5hA4T3cfpmkMebzl","st_dist_08":"YcnHRIxPF5cJ7SEmDLnmJZg8","st_dist_09":"87WYGKgOaSkTUk66JDLgL82k","st_dist_10":"HYNgerQVFEQIZ865TzMdKFri","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ufWveOT8QAEOgSjGAn7FPES5H6Zj8kKj3fNggaXpKyqrG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1368,"st_w_id":1,"st_quantity":48,"st_dist_01":"PMrUPV5vN1ZwMHX6qNN0G8eH","st_dist_02":"zTt9uoA2PPZ1PeknyCZsZDV6","st_dist_03":"J6phW0sIKXBOiRgrcfOiH5LC","st_dist_04":"8jdWTwr9rJRftGrWrEtUycg6","st_dist_05":"FR5LrxpPwrpYXDoFagPEc7FW","st_dist_06":"p2pkGFJ8cGhTmil3dTY6rQTZ","st_dist_07":"DDBqh5nFTHGKaEk6vRPGLdZJ","st_dist_08":"KCs0woLM0shD7luJsnHUhXUL","st_dist_09":"FfkjeIIZWOp794d4InSsoJEh","st_dist_10":"BRytV9YgibpWrAlUWlnIrkHD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WNgV4PfBS1fttJ9ckUTWtgXP7hjOtIyRkDiJZ3p0p2peU85tA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1369,"st_w_id":1,"st_quantity":100,"st_dist_01":"BjH814lqVT6LBuuszjj7BWZd","st_dist_02":"ptQhjS32Zy8voBmZAEMYdcF7","st_dist_03":"wNm0gyEqlT8QZkUR8OH1sCMQ","st_dist_04":"SKGkL4wax3AOfkIg0IJYqyk8","st_dist_05":"cAIc1U3FWB2hvLL3g50IVwsA","st_dist_06":"ekoTaD9kNpJQL5qqNhyaj2PS","st_dist_07":"BbIFZG1rJq3thXGHq6EPHGfr","st_dist_08":"rS3QYbQwATGCZmDauaUoFIUD","st_dist_09":"LZ3nBUYbSBLUMxV8hrsuvbJN","st_dist_10":"hiMl0xBpBK7xafu12OvLRvpk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9A5DyL9JhX4C9YnowSRyrYxaQXu7w914sNotzBkZu3MC5N0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1370,"st_w_id":1,"st_quantity":73,"st_dist_01":"bTFeRYeSfysfsKXdiHHByYsV","st_dist_02":"doHWOUGKKcaqX117IBI8Ir70","st_dist_03":"6KsOHJmJdOaa62iQd5XfV0od","st_dist_04":"oQMmmPo1itH5xaeaGX7pchmK","st_dist_05":"AKB8pMpj2Kmq0viJ76DLJjmB","st_dist_06":"78N7xsu4Bz0JV1eZ96W0eMtq","st_dist_07":"ldiEVTzITWCKzq9OVD6gnk4j","st_dist_08":"vz0KcnPzGaHw3gzg5KJL13TB","st_dist_09":"pa7K57p3Phf0PWQ3zbuRmt2d","st_dist_10":"xeOZqL7EAdKgoR1gCeCOStd9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"o3w6c6APYGtOHVfDLZKbwMRvgEEOZ5A4ZUG44MLo2MHnFf3Hhl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1371,"st_w_id":1,"st_quantity":13,"st_dist_01":"b01TMCVZgolW2KAPTNQRlrCB","st_dist_02":"qP74zFlzwkOhIQ4773wWO5hW","st_dist_03":"LNmFwlBjIQWqEnQOP3YjcKMr","st_dist_04":"P76jq2UONeVEDEDZ0mB7gr1l","st_dist_05":"jVAz6dAbFxWFUnqu2R2LJMS2","st_dist_06":"XgXLXsMYdvOH3kU44fQTcr5R","st_dist_07":"fDz3bxbWqNmwWAULMIzAajTv","st_dist_08":"0i4Ye0H5m1R35m5XrJxKkH8E","st_dist_09":"8iviqQCPF1cOqEVW14bHrpjI","st_dist_10":"hWeXghi6JM9d81EDosNTsKcN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SJIpqai3wtsNdqwC8YpTua5fR1yq4vvyH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1372,"st_w_id":1,"st_quantity":40,"st_dist_01":"C0L6dkE9XArVbXgHwjfHXT0g","st_dist_02":"wIwiUrVGoyyIIaCvowTApbZx","st_dist_03":"tXM3P9LQxyJpaoFSqOcxXDRU","st_dist_04":"CmL0PIcb0JuK8CQ2YPaGLohC","st_dist_05":"g8vieiV6Dng0kxZXx19me1UH","st_dist_06":"FqiqkcjzLnQs5OXIRkGyqpd8","st_dist_07":"kOzRCr5a8yUaqZWEeNCFKJqH","st_dist_08":"PJym2a4kZhgcHOxomEXJ5uB9","st_dist_09":"QGx4HFnXzgbT9oaB2RwWjH4f","st_dist_10":"zliLE9XB8taQqcjtjDDAzwqI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"H0Xn1efdk6L0eFIX7bOEQ6kLoSe3oPoPUc7W8nVY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1373,"st_w_id":1,"st_quantity":12,"st_dist_01":"jLoZJlIYOe6e8vAurtrqJ0Lj","st_dist_02":"DYm7vOoN0o9o3eVDlDlygRW7","st_dist_03":"u0Jw14JsW7srRXk6Wd9bF4i1","st_dist_04":"bfqg7EmoXzesH9NHASEe17F8","st_dist_05":"XmK9490RfamanQTzGK91WXcN","st_dist_06":"Y1jegrDkTnJDq5xJILbljQkg","st_dist_07":"blP5MhqnbICIp5WbSE4YerMS","st_dist_08":"pW0rhczl5MGCpiOnuMQVM0Y5","st_dist_09":"9HctwkGsykhxyj4XXEUbHh7d","st_dist_10":"rd9VltVFtJpqr08Ax5bigh90","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"bso0nmIlLk5A8DWR7d9WpMEq5qPHCy0CYCWHB0uhVIlP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1374,"st_w_id":1,"st_quantity":65,"st_dist_01":"RTgBC80aSnU7ZuP2ihJ50YUw","st_dist_02":"WO66olTtNCz99KvQ89C7Ehcu","st_dist_03":"9JpOKINcqwEm6UcFuBVw2rHn","st_dist_04":"QsB5uF0QHVHRW36rY2GMvXgj","st_dist_05":"6R5Z5K0eQsvOLFKGzGZGJBWZ","st_dist_06":"RkPyNWCWjN4wgLcSF61ZEX0G","st_dist_07":"m6scqa8Q6Qo74kq6gcREvGrC","st_dist_08":"8yz4aZJ3l6zBVd1Jvb0UYf2o","st_dist_09":"dZQ31xlAOgfPHFm63H2PBg9J","st_dist_10":"qt0a4vklV1h6LDIJvmVdha3n","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lgtvMmjEBc4B9YJNpGzaVzckJUhlgBDGopSCg2ETQmsZFlH5OU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1375,"st_w_id":1,"st_quantity":68,"st_dist_01":"q7E3r2SzKAoTykHksTrUVXbC","st_dist_02":"lCqBkmMNp6wDvDrlz9B8eyjX","st_dist_03":"wNcyGnqRNVQJYq7gGEZzhJ7E","st_dist_04":"zDmWdIK451DlR3SwZ6CJcvcV","st_dist_05":"oOuLsPNeLn8pwYeVhFz2uc9W","st_dist_06":"Q8x4GGfhBv7N14I5mthq6j89","st_dist_07":"4Q9cULz1mQyzXsj1prhCg0sl","st_dist_08":"3VK0VO4zaZXcy00BvPMTCQrI","st_dist_09":"xOUm0TJjVwGx22Krx7NwfpLX","st_dist_10":"upju9mEL1U1zpj47uGRp4KN9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"QypFjp6GzGm41Xg1oDuPslIll30Rf8CW5H9TS8oZXrF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1376,"st_w_id":1,"st_quantity":75,"st_dist_01":"y9uthkg3GAX92eVqM3oxwxqu","st_dist_02":"Il4VZx2Xlp7Lc5Z052DpAKZ2","st_dist_03":"8Br6kMHpWQYklwHdI4vxCZkw","st_dist_04":"DiTwL9VCKTNGcu7PSfbHk0ir","st_dist_05":"6fMDVadbEwreLiwMS5dXLsyd","st_dist_06":"MAR93NLRLEeCEBBaTuMuoRfu","st_dist_07":"rZgfEWkjPESCC4lylc8WvyFh","st_dist_08":"mqsXcslH6eM0FETKLFHJOcij","st_dist_09":"hSLX5yxtGwO1s1w4vRwUr11K","st_dist_10":"NPpmMGlcixAMyJefN67yBeFb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"SUyWNprhIMzzblwaJIdFO1ePEBbGzPSRJyobiAU4E"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1377,"st_w_id":1,"st_quantity":70,"st_dist_01":"zyQLZNsAF3iaQLzO0oLiw0mK","st_dist_02":"mrHem7XyhM8eAOsQX2ufkABS","st_dist_03":"fKQY7XEiy2ykRdcSwUSO8hrF","st_dist_04":"2krMz7GPCvUHpd7c7x0hfwaF","st_dist_05":"SqvvyeaT1guzyzihUfoZJzKu","st_dist_06":"Vpzhr7S5DAJ8SGKvOdaN1IOl","st_dist_07":"0FpjQzTbuDFhvZnhLpLE4hBs","st_dist_08":"xvTczzXmOXanyclP2wAisr1q","st_dist_09":"Xctic5hEq34nNXzHAPhgOcT7","st_dist_10":"xeQNxEL5qERGQZwHAAZT6ONO","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"s40CthTLzZx3BqBcSQ1cmr0a3QIB3okH17I"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1378,"st_w_id":1,"st_quantity":44,"st_dist_01":"bCki280UrYtUkQQF6JU1Du8M","st_dist_02":"0fNVFDmFicfW5sQcPEXUWmsG","st_dist_03":"SRGZAMokS6lCVzWSpvvKfI2n","st_dist_04":"0ujjVXK6wGtDLR5p5WXnE4t2","st_dist_05":"X1Yr5kW42sOlVHCh5vmToFij","st_dist_06":"2avw7cHfxjBb1L13gd49BnDC","st_dist_07":"83EamYvMEPkIBL8T522yzgeV","st_dist_08":"f0VhyHyZ0zT75Gf9aYcFnGs8","st_dist_09":"HHNZUEr3OzqOwlsBwvuNMYDs","st_dist_10":"JaVZRexdHqwFxJoPrlRSQerb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ArjCmMX9iAFkZS2d6ASM8X5shLjxT585xqkrFw4IBKzHTkyZmS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1379,"st_w_id":1,"st_quantity":20,"st_dist_01":"MuB9o4OXBEXJ5OK3ltDUuOEU","st_dist_02":"GKg84VOBJSKEIQ84P4gcinHf","st_dist_03":"HapFO6QEe4cBASFMBKKsjDeN","st_dist_04":"ytjI5z8l6fcHZ0rt427vaJTj","st_dist_05":"KUGQk7pWWeQbtbbBQcHDDHAU","st_dist_06":"qjaxuScU7Zk3xdWBnKpeMxkP","st_dist_07":"nohWZLI2pAPseKJvlWeGSEFf","st_dist_08":"0Ry8jVUOTkOazgLuY01joz21","st_dist_09":"ICBsKP1IsZyxdhHzDNJiGKRc","st_dist_10":"zHoVyXWLjlpCbgZK0L7Hn9sx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"CqAHpzRanx537o0ZvPcbjqoriginalkYBNO4w1Ok"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1380,"st_w_id":1,"st_quantity":44,"st_dist_01":"wRDoPo0o9mWwguJxHf2wycxo","st_dist_02":"2qZMovplAC5W65xsFWlcraS7","st_dist_03":"2L0DLvsQx79bIugh0t2c6Wez","st_dist_04":"i6iW9f1liNMDwWtGM4VhDRLQ","st_dist_05":"gF8pusyEaTMvVm8llgeHuEp2","st_dist_06":"VBHFKYj2P7E87LxrphIsBGIE","st_dist_07":"8L2WTGVm9DD6FNtegzDIvogL","st_dist_08":"mNNiaL1SM1K3LWBJCFagVRje","st_dist_09":"AMS8gyo61VuSlSWJY276daeI","st_dist_10":"zBBKc9DIRDsFEL2HikVipRl6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YBLX4JmAr1PJvt1lfqQmnyFYhjerWJxYIu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1381,"st_w_id":1,"st_quantity":52,"st_dist_01":"aCCkbSzjCe4mY6u9xLtqgL0J","st_dist_02":"LUy5e91kgwn0b10ugpDmKpkM","st_dist_03":"OpOUaLAh4YettIOuM6809zI7","st_dist_04":"l6imYxoQkFp2jjMnAsyoHaqR","st_dist_05":"XxjHmcyJqHtqt4yi9SSYeJSF","st_dist_06":"qIg7fHQ5ATBWAp5ivzaCnrSt","st_dist_07":"42JYBKhxlGAe2Ao04YhROoHl","st_dist_08":"xSzph2DtMwe6mrPEr865nDHN","st_dist_09":"iFiwE5QITDDO80pbZRcjorwL","st_dist_10":"LkyEypUYeBY6I6Ex0nAsIOsE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8eex8DJ5Ec46ReqIUsMs8j29SlrdOUXI1goqVK3pDzOE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1382,"st_w_id":1,"st_quantity":22,"st_dist_01":"Ca2jof6r933kpd6QT2LHMQHU","st_dist_02":"psSWq8EPRZnzUubsqUXERVGT","st_dist_03":"kafqnBXsijPHyD2db6VO4jgO","st_dist_04":"cZNr4kNJNO60liIZxIweFBLX","st_dist_05":"HLPd9hZ4Ej4bJGKwTBtcrIKI","st_dist_06":"qTbY10qon6kEw0HQjmOk6LVk","st_dist_07":"fXrP88ga7QSch4AFj0HsTOxN","st_dist_08":"TXayit2Ko4Wr3dDpXIIuFN8o","st_dist_09":"F2xhis6t047ZEqEnzLMOWpQd","st_dist_10":"afFppg7zQ6CHMCV0m4LKky5Q","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"u5JIMOLuxO4GKSkYeRffhUo3W5ttqWaEmiW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1383,"st_w_id":1,"st_quantity":41,"st_dist_01":"XUXKkx8c6MLNWDoosiYhnkzK","st_dist_02":"ckDS7pzvi8DABeW7Hfp0mUmY","st_dist_03":"1hg15smcbta1wKqPDYE5JTMl","st_dist_04":"3KFOeQ9iane93iXb9hM2ypbq","st_dist_05":"JojWXi5E7CCPSN6dHLvTyYdy","st_dist_06":"5WlW6ELIba7MnAaeOECBazoo","st_dist_07":"YKVzQBn7LtbCZUqj7wzpZCqB","st_dist_08":"6DlkhzJ5zs8BcFf2K3ZhVZq1","st_dist_09":"GZXuvvcgF64ub1wah7UayR7d","st_dist_10":"rlHwWQ5dn2MgUKzPGT6n8LXi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LxE3YGxpniHVA2fJrap6YnCQ6kZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1384,"st_w_id":1,"st_quantity":31,"st_dist_01":"EyhFMeCtvEOZQg6o9hHlWUuK","st_dist_02":"vsoRvo5OgyMWqJqDoKSNf79P","st_dist_03":"QkCzQoyll4epMmaSOB4KxDkd","st_dist_04":"NAZ41Pmon7gRoikzuvllKxvG","st_dist_05":"kCnzMrGGg2FKSCRZiXydE20z","st_dist_06":"rk2LAqviFb7Ew25vr4LeCq0D","st_dist_07":"GQIOWwUeabbRi85U8rlmeVzM","st_dist_08":"HybjzCQKAHiObvkWq75RJSZi","st_dist_09":"n8W13Y6MzJVYzyNMsYB42m8c","st_dist_10":"Dx5WzNTHcCRbK1MKJbGUdoGc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XIbMpn1matZft0fgc02HRGVV2LoVk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1385,"st_w_id":1,"st_quantity":17,"st_dist_01":"1hZXDNc42lLXt3nBDdpUZxHd","st_dist_02":"pEVNgFHCfVbJUVx5nFfDFm97","st_dist_03":"YFilyDKvA7x5KgeRknp4aiDn","st_dist_04":"2z9rrY8Rb3Io0MLupdlUtg3x","st_dist_05":"BzgacgBpUVdBjtP9coMh9XNc","st_dist_06":"QoRcdirlfSTLmXeWtbnFaybZ","st_dist_07":"sQnVWKstcYYReLL6zZtJo8Cy","st_dist_08":"UiWJSMjpYArI6zvERpR9s8Ng","st_dist_09":"pdxE1vyLfbZfYjklNm8Y6Tiw","st_dist_10":"O77jBjfFUHh6RaMYHlEuornF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"egwqjviW7Syt7EfHKcDQjaM9Yg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1386,"st_w_id":1,"st_quantity":53,"st_dist_01":"VXPlQvSdZigcNiNEE3qBBWUi","st_dist_02":"mRLqyytfbwHkRBSg7OhQbic3","st_dist_03":"ti7bVRma4IAGVEWmXo8hSrjt","st_dist_04":"CWN9sxhKKsT7fTs6akjZkoFq","st_dist_05":"L1Jpc6POQPSebkEjR274rCWa","st_dist_06":"qgzQq6Ciz8q81a9xHEtaYwkM","st_dist_07":"KuwapPmQXq6wDPVm4tWTxQBg","st_dist_08":"B9j4728D1IoCWByUMgmjlsYs","st_dist_09":"3JSwZA1REYBpiGNkymSHvsIR","st_dist_10":"ETAkvg3nvcpjNK517uqZiMEU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zBraQK7KXZSoGFTs9ixllAojcCnO1PEV80u483v6eH86N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1387,"st_w_id":1,"st_quantity":59,"st_dist_01":"BLh6OZfLhmHaImZ6MSeUznZa","st_dist_02":"MBR8Xw2vre3PgpcnIdEajTRD","st_dist_03":"VuGiSGEGjt8sBGTM1Ly8E5kO","st_dist_04":"0npYT9xdHKGnNZIha7y0hxry","st_dist_05":"wIdDkVM1vuxC4FDwuWpUSI9U","st_dist_06":"4CQtPPlAieD9UV6vx2DQHDuX","st_dist_07":"DOGp5SqcUDW17t3JzOOgBwSG","st_dist_08":"UX88nj7UqgNzPO9a5ngJthj8","st_dist_09":"jfPA3xyUdm2lTvFA41CFndQ5","st_dist_10":"ahW6eXgSNcJpZ0yxGpDobYvf","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"DmdjBRUfu4on2QXHgxEGjZYBygWtWukHUXTXOlHkv4aL89BxYF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1388,"st_w_id":1,"st_quantity":83,"st_dist_01":"gkjTTGOjRTL2GCJUqNJmMihC","st_dist_02":"eSBYsKvvKbaLGx5UcnAMU49V","st_dist_03":"jZwo9DkBKEZRb17frJMetU7g","st_dist_04":"ogyM6g9zFsGc8gdgscV30YEC","st_dist_05":"Q9IqFrGBMC4PNPYKyWiK5TEr","st_dist_06":"NcWeCYa1OOaDH0hx1T9nfQSY","st_dist_07":"Qc31prRy1pWsYv8VxZbSADEE","st_dist_08":"6vHTzGSQzI8EvPsR00lW6Vuj","st_dist_09":"U5zWkoPW6aT1fQVMql6oq9nC","st_dist_10":"wnFFtG4cjY7V0EIFRImcxR6j","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xHoNqg6krfSSrGFNws9u3Fbka6qhqV3XoxPtmsvui93"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1389,"st_w_id":1,"st_quantity":46,"st_dist_01":"9jOCRWhmGJNw4Kwirqf42JI3","st_dist_02":"CUXUerQ36PG8ydBKm74qhkmg","st_dist_03":"fljnpnWltky7SDLvsmqkTbrm","st_dist_04":"YLaqmI21Ft6RpmXpBMyCEAW4","st_dist_05":"L6jdl8VGqn6a6lCwQPyoZjiG","st_dist_06":"DWeDybmIBjPWTUNNbWWFjZS9","st_dist_07":"gJcJMrfCDBgfQ0IpDKtRWrPs","st_dist_08":"PQW3vgKnYbZkre77kUdmRb4p","st_dist_09":"sart3x8kiTZbRCA8pHnds00h","st_dist_10":"3uPMkEtfc65pADHHzl4jvRim","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"npXavez2cUjnRpzkLVdkFaSlwX6v49hlaOdNMpUo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1390,"st_w_id":1,"st_quantity":21,"st_dist_01":"B8JmWRtpfwwNa827Sh364eco","st_dist_02":"WyybQGypI9tQL7M375oEyNR7","st_dist_03":"rovpRFZD60sr2NTrdR8hCMvW","st_dist_04":"gkCzYtmACI9J4dxriyZ2ukLQ","st_dist_05":"Z5rCCWv6r1W8FIM57X6u4ovo","st_dist_06":"2jMCJrCIAsLpReEC0KtcUhuf","st_dist_07":"Y4du2JDcb18acqtztFU2anRa","st_dist_08":"RE6vbljh99Rt9o2BIaLaZ0DG","st_dist_09":"MzxlpQVqN6LSPFBpFdBX2lnN","st_dist_10":"3JT6LXGZsS0Zb1dsb1Z0CPrg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5a4Ne2b6yPsczHWUqqLnGHfCu4lG5PzzatvX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1391,"st_w_id":1,"st_quantity":81,"st_dist_01":"wgFVTrX7XIOY41Md1xmwFdj6","st_dist_02":"PNJiuGWCUbulQkK41yIaInFJ","st_dist_03":"BNnHi6jR8dIWLyeMnrmbDOsG","st_dist_04":"8Qx8TGt6vpT2soK0gnCyxXr5","st_dist_05":"WCnxILtEL9qqZ6B2ArFKF5xI","st_dist_06":"rO9pt1wVKpLSj0AH9H9sSCJr","st_dist_07":"laZX3M650wlUmseZidkhsAXO","st_dist_08":"TkUfaTW9bZYkNMSuVEVSg8zQ","st_dist_09":"UePwaGviohUwQsdI7n9LFqjj","st_dist_10":"zBV4EyDGkbMhu7OucImYuIgc","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zMYzhjG4Etb8mNEwzBuWDUsXaeUiHTT8Pj5yIJadID"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1392,"st_w_id":1,"st_quantity":30,"st_dist_01":"swuWQH00YU1JGkUYQcnO06wQ","st_dist_02":"peE17SheLu0p3TBR2ajguifN","st_dist_03":"8B7QdT1UZFy0zKVkEE40pjFp","st_dist_04":"oyxtPCefiw1GNmp6WOACEt0i","st_dist_05":"LVRn3oEMcUtt11cvB6ZgkjSf","st_dist_06":"GD4KoJ9vYumYFPZvSybbroJ3","st_dist_07":"WU9cGXCGRaxkSz7KMl4pHCUV","st_dist_08":"VYSGRcXXVkVAPJ2N0M1o0gY1","st_dist_09":"9djuX7ldb6lYYyZ12eoNFFKc","st_dist_10":"QhO4C1WWNlu5GEwjm47t7zSF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"we77aJ0wa77GUw2LuGloPu8bm7doriginalT9jFENLHxcUP2BE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1393,"st_w_id":1,"st_quantity":28,"st_dist_01":"WepWjc4kzXm6XTv01TwV3FFw","st_dist_02":"Iju6oDRSEGwH2en8TsVkl8SY","st_dist_03":"ojEyqryoRgw9wYLExcQX2Zac","st_dist_04":"1vbuVjl08xpIPhhpbssnkSb2","st_dist_05":"XBpRy9SYldMDzSzhsvUcf7pT","st_dist_06":"yFSDpfn14IuC3qQ91PTZFldS","st_dist_07":"iecY8SX8bnMi8vLtmn8NCkLL","st_dist_08":"baMueJlpiMZ9I463Ap2F3ny2","st_dist_09":"FxcY9eNedxGkZPd9ZWj4jFXR","st_dist_10":"05OekiGOH1ptppQDIM1dtS96","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NwCwyO81v9KOTuyTyE04FJsjvTefd0K9CHbnDP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1394,"st_w_id":1,"st_quantity":79,"st_dist_01":"26hqpNWMYKYxUXwxPuYyub88","st_dist_02":"QIR42eDmHHS7936sC7nj2hUB","st_dist_03":"GapE9gpkdOrVlhtearJv5cmB","st_dist_04":"LjPIKTwNODIoNvSlyeZc7zT8","st_dist_05":"33jnkOjKs2qmqfQ3jurKZkAy","st_dist_06":"pEOP4f395OdcUN22eFAhVYzu","st_dist_07":"sAG0XauS7Ne4CcbkbtXSWrZr","st_dist_08":"mP2enJdVyaVMKV2fBmw7Rjdg","st_dist_09":"kX6cqbwFO0ljVdh5LKd1E2xr","st_dist_10":"Hcdr6sncjj5Bu9d64Bs0kTf9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"968QY7qr4GFmTpJuxFeWVLW6OEoQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1395,"st_w_id":1,"st_quantity":91,"st_dist_01":"46jebxVDGLDDy5oGlCfpzrHO","st_dist_02":"4OJI1N4Mt1YxQrZ7KzYQs7yB","st_dist_03":"VhUOu9r4F00BAY2anWxGq0H3","st_dist_04":"bhN8JQnU3TBPSZ5TnGEDICnw","st_dist_05":"0rQJgSWuBu5wOkJPXEEw70Rv","st_dist_06":"w6Pani8yqZfRGMYkhNAVoAAL","st_dist_07":"EYnWqbdM72vUh9adC94vnaRP","st_dist_08":"iVt5rf72HwtgbnKPUMryXRY9","st_dist_09":"7j0dEDmLhSQpR3gVLJEIjsQB","st_dist_10":"cOO1esDXSLflThiKJpN1D4wt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"zfYxaFcBErUPsC5s36JRAT00XMMLvuQdD1xrcCJMQN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1396,"st_w_id":1,"st_quantity":93,"st_dist_01":"XaKPC9vxkoJufD2UtLiDQrZB","st_dist_02":"lgFTR06HtvJoslH4jTlKs5jv","st_dist_03":"Nh9aupuv80bNB0aENxgD7njZ","st_dist_04":"eh2cEdr1zdcHOh0NTziLxvHs","st_dist_05":"0Jxm38j5yrPBZkY2f1hgQJGw","st_dist_06":"ZULrOr3DDO2DzzWCZg2ahO9R","st_dist_07":"wJlW3f20KguNTXY3NvrLuVSh","st_dist_08":"223C8sLD5c20s3e1Rkror6Du","st_dist_09":"dpgdrO3wRIx7XhSuBG0BbBhg","st_dist_10":"1C6AeawAcACCz43kIwEMMyH4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iPVt7xzYwREMxUfXoYggyt4yQhPMtHYr0JTl2Et"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1397,"st_w_id":1,"st_quantity":52,"st_dist_01":"GsAP9GS3pBTXYBxUUkJDCCbq","st_dist_02":"RRHUmMFr9I3ufP24hYq4bn5u","st_dist_03":"QQcaPnOrphZcYuFIIVSFxocR","st_dist_04":"X4QbcWkAZOGoEfLraNbV8EjW","st_dist_05":"eiBWftHDVu8tbgBqlxx3bdI2","st_dist_06":"nHdHLJYMbHwi5NrnzSByAS52","st_dist_07":"0JojXf7MHx8CUSrGln5Suu50","st_dist_08":"I3qtI3SKuvFcGU4DxLFVlXGR","st_dist_09":"Z4hgD7xwZJrdivS0073Icc68","st_dist_10":"Owzs9DTinyfHXCeBkzPQAsYr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"p5rTthrx4WmZpcIwTkdHMmwFDMV4hp3GdTmU2SKsLMfu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1398,"st_w_id":1,"st_quantity":11,"st_dist_01":"73qJq7gnMTfE7VXY84Qa7l0M","st_dist_02":"igpoCSYNIRWDI39jvEm8Hm82","st_dist_03":"7YNVSzlCMaH0ubLtLnTlicFF","st_dist_04":"JabZMxx3F8QP0NSr8y9ybF5R","st_dist_05":"Nmfw2tBwPWdCh8LQHt27CGuv","st_dist_06":"umvizo9lxQEfc1MM0K4fuHIA","st_dist_07":"F3efvgXe1grfR7zvyuVxbET1","st_dist_08":"BvSrz4lphMXbNi3u59vN1jzL","st_dist_09":"VWRUvXHw12gB0Afn5FbfD3KJ","st_dist_10":"AZAHglRDPdYQZGXasjJ8Ko9u","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"A5y0hHSmZLnisxxyYNQyyhaGCuOnJUBfLG51BXqAJmQCYDUME2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1399,"st_w_id":1,"st_quantity":69,"st_dist_01":"eaDgxIe4asNOC74i6zl3aCDt","st_dist_02":"nry6LejsRaKXJXdkRLPPb3c3","st_dist_03":"TbqOLMsMjbWaSF3Iivj59f4v","st_dist_04":"CUfzb0anoArBMHe63b9iahDU","st_dist_05":"e85IP8hW2A2JZKryVcNpTRRe","st_dist_06":"DQsYPQm2udNxuyKwVs16vZHY","st_dist_07":"fwAEQLkf0pMhrrhNkdiKegaT","st_dist_08":"t2FnLGH24EkGb6BfzR6zf1J4","st_dist_09":"BroeEnGLmEI3VrMxBlkzue99","st_dist_10":"Tk1atuW9aRhmB12mJExkcWmn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PPMDLtiKlYqjWSGMioiCUTalMlPyoKzrULJNqQlmuTkNW2YYxM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1400,"st_w_id":1,"st_quantity":88,"st_dist_01":"XpzdMuXRvhzjnv4rcu64oXWO","st_dist_02":"B8XEZ4xQDitQDNiCZjlNdzeO","st_dist_03":"uPyo2OXEpClKBoT0b2G0RQPg","st_dist_04":"hX73UhuK7acaVdAUNqy22Bc0","st_dist_05":"utX40jI4ARDWu4QFNpt9F3wb","st_dist_06":"AIMwRJBrNR80bgEEddk5VLsL","st_dist_07":"jQFAelqnbWdkZRfpuQnmQoN1","st_dist_08":"Tg6X5Hm4IK1KpUFX47vRDsNI","st_dist_09":"7VZp1H6Qfvj1A359hagrMZpA","st_dist_10":"2WEtmJk61hF7qBCf5HYPOfm6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"MrICZVKScU0tIofmz4FdZqakzojlnsfLSqBVklUJDWryMVn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1401,"st_w_id":1,"st_quantity":49,"st_dist_01":"SKCfGGRz2aJhOniTVHdOZnvF","st_dist_02":"cYdc3549fFq0uzlapI2ilSHt","st_dist_03":"FNpOjMrlXkCaYH3ZeVl0oMfQ","st_dist_04":"vYm86EFHOoxgBmKqDixyzniG","st_dist_05":"EZoezCChM5Z80tS3mSQEYLrl","st_dist_06":"LrroZw7qHubW6Y8VWImMUbuz","st_dist_07":"ZLg3nXASxZoBmkz5FM7oWOr3","st_dist_08":"gRlWrQaSU6oKpwjIZChvoUnn","st_dist_09":"GkyWz2WZxQWgR1aglqVySyiC","st_dist_10":"9w3lJYYbf4pQOXWPLxghOUI9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ht6boL5RqqT6qrpChcSmlEmthwXnHbcu7cPn4l7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1402,"st_w_id":1,"st_quantity":39,"st_dist_01":"qUn517GtbNI6Wc5tQmi1qjql","st_dist_02":"hrTpgD0rTZYcZcgxE3cBNKlF","st_dist_03":"OoLuqfsamJ2AXehifOBOEylf","st_dist_04":"xlZtGOikByk0beCLB8sOkKHE","st_dist_05":"GWTqUU0Fxk9vnG2DOKmUM5De","st_dist_06":"dkPUYKre4ufJsAWfAawS68Xv","st_dist_07":"9HXptulILAIJe6my3M5Yqc0s","st_dist_08":"mabFc7kuPCKEUuTxeFlt9ipk","st_dist_09":"rismPpUBjHi1AC8j9NOYO54P","st_dist_10":"7HWsxz1iN3F3hcid4csUddAz","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mF6DGk60YFfio9rstDdSh7CML6NdeiMrwMRoeFwN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1403,"st_w_id":1,"st_quantity":85,"st_dist_01":"8UE7W5BgzGb36IBIMdbUAroX","st_dist_02":"p2vkIJSveNIFJFQ6CCR3f2zT","st_dist_03":"WWu87iY9nhTeCn7DqS6lM7KN","st_dist_04":"vEby8QfpWF6nldUw3T6D8LCs","st_dist_05":"6OpDjXKOf9w9Edtf4RGzbsBQ","st_dist_06":"dN8DEUlu3IZbiiCypqOaWKB8","st_dist_07":"aNYtREtLDuaWUQ5qIlX9GxqV","st_dist_08":"txgK2Vq6jils350r1K93AqzN","st_dist_09":"7hbYUoL1D8TMJNGNszFjLX6Y","st_dist_10":"NT82Rt0K7hV5bdQ9V6Q8rEjp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wmJZhIBReR6V0ZWYGOtSbcWC3IH67PZOpAkiubkNlj9yXka"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1404,"st_w_id":1,"st_quantity":40,"st_dist_01":"PwnawhZP6CPiWs3t7kWQXvEl","st_dist_02":"dfJM7UB8Q8iQMdHszw2Xcm7O","st_dist_03":"HMxzIlq1nQZmRmHJEEGJUIoR","st_dist_04":"mo4iTSdyKG14BZMXPs9YXvPS","st_dist_05":"Yau6b3zNWfKgylcMHT8kK5J2","st_dist_06":"1JyGgOfoMnKdxIIbSd1UBbqS","st_dist_07":"YBNthoaokUC7gPZWa1QebdrB","st_dist_08":"uJDEsJu5cP8U4fAQFLvBJ7oo","st_dist_09":"FoDqGzMdfR5tjsKX1XeLP2X2","st_dist_10":"0ncEkUnHq6IYES3bY37XUu6B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"TRn52b9LNPLl0404xNMhYs4uTsCRPUH7BN1"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1405,"st_w_id":1,"st_quantity":28,"st_dist_01":"TGj4tVIIWMbp1HHZYHuvb74h","st_dist_02":"1lPIrNfQdYi1GydlOt4F7lMV","st_dist_03":"UnSc8Fc2FpywBs0O6eudwO3p","st_dist_04":"w4saJ4nuJgcn6SrynVvZEIY1","st_dist_05":"dafhuGslxdHzABN23qYRjQXi","st_dist_06":"kEaJ2rObjSXh7ObDpEFfprAq","st_dist_07":"mGcDYRQ3xmAPejOqS1iQlrJ1","st_dist_08":"7EmDgxcaERe0NemX0sgK2gdj","st_dist_09":"fEd4EFZBarPK2Sy5g1UdSJ8Q","st_dist_10":"9EFkyySjC48DSMGrMOydk8qw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"lPj8moFVGQ7ORgYLJyO5HWi53EBN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1406,"st_w_id":1,"st_quantity":18,"st_dist_01":"FDCzQ9i6p4tL2PWTnw23Hv81","st_dist_02":"ejvLakhHhtIjbFgIWCwgyJxF","st_dist_03":"9bTjbmnawIrsXqTkJYeSewqV","st_dist_04":"vgrESTlRtNHp5qTp1UXy8x42","st_dist_05":"MfhQB5T2H8ZCOvGaI1eecW4z","st_dist_06":"8EG8cEau6ErfubWQ2zuDVq60","st_dist_07":"FpOwewQw75QqxZQWGQSD2L9Y","st_dist_08":"rPwmlwOLg6jEDe70DT1dmdhn","st_dist_09":"NHyyqbokkNKv0GPyySEnzsIp","st_dist_10":"mdJuTzAlURZZxcxEE5M5JP5S","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"t85g2qEhRvWtuMqc7UF4E65hW1nier"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1407,"st_w_id":1,"st_quantity":59,"st_dist_01":"Sly53SVXycUzq2UaTPQBqhFz","st_dist_02":"FIKegZ0aTgWQLFagjjhPAO4b","st_dist_03":"pwnY1vvlE8XfT3NixS5ZfqAk","st_dist_04":"m318OHYB078LxUwP3Qvqf7v9","st_dist_05":"IQvNBTXcM41rOFddYUo5oUCD","st_dist_06":"u0XMJwFbx9uPtoJ1qJ8Nq37d","st_dist_07":"zFAMvmwUbpyudGt5PYrh0sCq","st_dist_08":"RSNPAlw8woakumytLOimzc5D","st_dist_09":"d4ycU9wP2y1du55EeZzGUxn8","st_dist_10":"7434J0qHtsBXl3vMOGVReFPD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2eZXmyQ86OQTA0W09JpQGu0uSI5TVg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1408,"st_w_id":1,"st_quantity":30,"st_dist_01":"YdUPPFTJrVz7nhAxPt1HfXWC","st_dist_02":"PIvUoKaqytvJdcValPcme6xC","st_dist_03":"bCAeLgHuaLlVGxOgjSKwNs61","st_dist_04":"2R60CJiHc9GVCcmI30QEa0qe","st_dist_05":"uKulB6zEb2ETENMOXy5pDYIJ","st_dist_06":"1pgecwG56BCrbS1gnqB8thMQ","st_dist_07":"pMGLDKBjhgXnglIh6ZkeV42W","st_dist_08":"eneXVcZKsWPQdJQNLYrsvfxN","st_dist_09":"omzuIFnFLV1Nlov4gRCaZcgy","st_dist_10":"LWJQm9SIroAysmsVEhWKKoBL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"X73IXITSv4G6SJDzjukn9pZMp4oB2DYAup"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1409,"st_w_id":1,"st_quantity":84,"st_dist_01":"7m8A4Qq9eNiMC4perqMvjlTn","st_dist_02":"TmBl5V66bRKS7EbBMhqwLiHq","st_dist_03":"lS10C2oCmt9SfcRmEMgnEPmp","st_dist_04":"Hu2iZtv7BFcBvA71YGWOnNdP","st_dist_05":"m2UgOz1vJh2KzPPZosKpQTYV","st_dist_06":"pqN0NFTFDr0b06oauQVy7Orb","st_dist_07":"AIvxwWeF4EJUqQYwt88Zgalt","st_dist_08":"wBaZFK7Ba5N3mWNVTXbUyopg","st_dist_09":"4tmHrSmIhTTouwpqnEFHkpEq","st_dist_10":"WzQN6q5QWoDox6VgwDi5rmm1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UqlLZxAUQrKYG4aiFTzzjAiwZ6tkL6haoriginaljFppTjMF9s"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1410,"st_w_id":1,"st_quantity":10,"st_dist_01":"IcNWEF0mtdBfoGGiC2A7xVtU","st_dist_02":"Arbl1P4oHhmjnlceYZWNSTKC","st_dist_03":"DBCQkWShc3jL9l3M4kYRuOCW","st_dist_04":"t5txHVXX2FNONN8negOySxiz","st_dist_05":"Em5hAMZTiHemOPoSAGaHrbMx","st_dist_06":"7o1TbHFUfGETHheQ0NhQgx7L","st_dist_07":"vvssqDXQbOkmaGou5QnYGly0","st_dist_08":"FeciTcQGViLT5veujjkVG90u","st_dist_09":"fxfX0bkNsLzvhnIeWkMdOtfI","st_dist_10":"h62ADuKTyMbGH1OESBNviIqi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"veLN9TRTQqIgEKUZyJW4eITaI6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1411,"st_w_id":1,"st_quantity":43,"st_dist_01":"iTKzR15wHwJ0qLUYrkKYJ4J0","st_dist_02":"PJynLXrAO6CevuyfMg2CgGRB","st_dist_03":"6NLQ6cEfLdTHu4AYjdb2oc8D","st_dist_04":"030Inzg0WirYVchaUJbQmx6J","st_dist_05":"PHUkfTzDiDE4JZEQD2QuinPX","st_dist_06":"QRDXMIQwAilZu1xzH3eoudVp","st_dist_07":"zOZlufrfmDYLPn2inHzyajHb","st_dist_08":"Pb36a8qbCsV8e1xH1e2BUzv8","st_dist_09":"vvZxR5UC7XVB7EwNuRoKTUh1","st_dist_10":"FqZDxqNumzCmljahHFDZAEL6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"p6kZvtj97dh2y2sf3TlOoriginalQn7R8RSG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1412,"st_w_id":1,"st_quantity":31,"st_dist_01":"rovn83OLd4wOOEkLI7Zh1fSj","st_dist_02":"M1ST0H68JIYWaEHgv2eVM8Tt","st_dist_03":"IQtifnaz9IaiajuEI88l4tOp","st_dist_04":"ow0R5zDAJX4IBXGJOXHZPwpt","st_dist_05":"mjYqOlchrHJhHsSUs7qJOrpT","st_dist_06":"Ju0gmmyhtB7qASpY8So4gIgv","st_dist_07":"v7cHCQuNfx9eUg1C8TioRhmw","st_dist_08":"fHIqaIcP7NKko03ESU4GPkKQ","st_dist_09":"YzhzoSrdoYx3ez3WgcDONaio","st_dist_10":"559TfgbPJvsQRADWNHH6qywn","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jMdOyMcOYbHPLVwkmo5dfUmdRMSUE5f7jv3b"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1413,"st_w_id":1,"st_quantity":14,"st_dist_01":"RBMSwtlmtR8sUc97swGps1mB","st_dist_02":"oeQdvfWiww9clmlG4JAsRGlf","st_dist_03":"2fuYQbGyIaSn2JCxIlyU0UFl","st_dist_04":"qRchn4Cot5o3hJq5h6KPGbVA","st_dist_05":"YhxS2zROI2cLF73gFhLCftbX","st_dist_06":"Mp9D4CKWjiamvqYXqdw9ZEjB","st_dist_07":"dYxU45pj2J53PRA3VnfE3JRc","st_dist_08":"nQ7qoA94URrZBJ7zgkdZGQ5o","st_dist_09":"EGM5GKsssJgOKYOSRP0Xok5M","st_dist_10":"9duo8JB3ekXtNkhcrhKrwb4l","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xfirmGiquARQoXW6fQx5zYcwPCPwkC6XZNR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1414,"st_w_id":1,"st_quantity":38,"st_dist_01":"sQTHE2hYN9UHXiVyxc7NLO7N","st_dist_02":"zasvY5c4kADaPnhKwq3rdaWm","st_dist_03":"5NgfhlaiUZpNV4w1ekaCh4Yq","st_dist_04":"Fsi8Gda1pkT5t1SElOXizTik","st_dist_05":"vxRfXIwPusiB20abrBHUXTRJ","st_dist_06":"KKKtnxm9wlVRFBQJI8wWUzU5","st_dist_07":"rbP1DLHmgX5Uym0F4oz6Yf50","st_dist_08":"ZAvBLfxdl5NdaNJbDzq6WIKd","st_dist_09":"iCAe1kROqISBgslRI4lOGhJF","st_dist_10":"d7A7P8cMdOzUuBvYH8wvfV1y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"x9izblVbkW1YbdTpnOYIeUFw9NGK6wgemhixms9plaJrud9HFp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1415,"st_w_id":1,"st_quantity":35,"st_dist_01":"r8quxWgWO6i6P6xNPcfBfbKK","st_dist_02":"Rfi2ngkuxBaqmyFl2B6O3xb5","st_dist_03":"NZunW54QDXFAfZgSBUYPNDS4","st_dist_04":"jSL0KFLtKJjDohzTj6uemGyZ","st_dist_05":"suMbm2qXRvBOv8UNB1h3ftyf","st_dist_06":"jRaE4sEKZogB5cOHksB8HCHm","st_dist_07":"SaRac5TwNKlmaHvEwh7yastW","st_dist_08":"BthkbQocZY5dLPuvcq7BCpbD","st_dist_09":"j2Whxj9VaL239rcKxBswMK5w","st_dist_10":"N5AYuepATCBLKw4RpS2rOhue","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"GMEXSipz0PM7XdmHK7Dp2X9A9qWhQgRpeJ0BhCYWJfYP8dtu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1416,"st_w_id":1,"st_quantity":51,"st_dist_01":"e0CkskIWrtzPAmjHCvoNTIOE","st_dist_02":"kcunnEUZahBiHaXsBXl2KrHz","st_dist_03":"AnLSpuU7fZJXc2wwqmOhJf3l","st_dist_04":"NLAhNIOAGx9VyU6GzC6bxZx8","st_dist_05":"ncsQLughMdSvUOcajUftwdC0","st_dist_06":"icIpm5idJwiOyIZyuwQJtg5Q","st_dist_07":"aM4ftVgwNOwuZ4VHhCfdtNHq","st_dist_08":"3Yx3BqLDZwl6fBKRz9pcR7WC","st_dist_09":"NuU1utooOC6ir9aO5z380pK2","st_dist_10":"7TGDE8jTlMkZuZJuKEaXub9x","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VrPEjyzDTKE5Q1wV4ijEwG9622OoN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1417,"st_w_id":1,"st_quantity":85,"st_dist_01":"fDtp5jPLgvc8E3QiOSct6llC","st_dist_02":"ez8miXTwD4EGQXm0mj0z9w8O","st_dist_03":"ZuloqQ1RdGTjNUCK7bV1DA4Q","st_dist_04":"jJWNb3Wo8oB470m5lSVvfagP","st_dist_05":"4mCLf9KHhrFSCjm3EIVPEXlW","st_dist_06":"e5f62XbWyS1rg4Pm0cGULjRC","st_dist_07":"wwudZGbPmTwO61uoEvLkGY5x","st_dist_08":"ThorDXnrekhtDOZNyaAyAcir","st_dist_09":"TUhBaOs4ZWYeuBY7JP4i3Q4v","st_dist_10":"XAQHAkbhPreqpKpsmn66Unwu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jNejWYEFsbOWTHaBKq7TJq7g8dV5RWD7Cbd1fcr3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1418,"st_w_id":1,"st_quantity":18,"st_dist_01":"KhB2tOgnPVv3SbWaYEduHuQA","st_dist_02":"f9LliObZxqLXQMDg1KkVM3dA","st_dist_03":"7XMrDfoaH2E87qMXS4lKJ8mq","st_dist_04":"97ZA9TuL8XkEMIEYZ1x2yjwU","st_dist_05":"rD0Mo6JOqr0E07FvWbY3tWmG","st_dist_06":"D3r2fdk4QUjoZlbFB9qz25Lk","st_dist_07":"VpGF0CyAFJmYSFOnGbnGMJG9","st_dist_08":"K0uhbubZkr2GeborO6LYfgfz","st_dist_09":"z7P1Ls5iYQT80N88GcxToMVt","st_dist_10":"nShloXB2rxmhoZB0WLwJnv2D","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"r4D3QRyjt4QxSCstSFxIEFu9TC39z6e5kOlsdwC79IREZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1419,"st_w_id":1,"st_quantity":44,"st_dist_01":"YCu67kxTj2vlzunL2wxh47ZP","st_dist_02":"BygU88Ju1j6S5OSDFmXwt5b7","st_dist_03":"3Jcw9Rd3fqgw28JGoJBGRnn0","st_dist_04":"nj1aELZrsE4PuRgKXH5bASp8","st_dist_05":"jfzRtelvdmRlOGTegRj3uH7l","st_dist_06":"ipvnDKApKSUTPYVRw5LrSo8Y","st_dist_07":"FrWg9stlyGOuB5JVZ2HbODqK","st_dist_08":"OACoc9nBL7dIMBuxbNLj7XnG","st_dist_09":"C9hAvqSMo5cEqvrmCRje7AYl","st_dist_10":"C7lCtut3k5hJJ9JDfiylHVxh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PpebgOQV9KB4gJFKa1muqkIWIsTCXSjP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739246,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1420,"st_w_id":1,"st_quantity":51,"st_dist_01":"ja0F9BJQSz6Z5x9F3rd8IeAv","st_dist_02":"p3rPZCclzU2ZKIMKLZTYOZHW","st_dist_03":"JZLFk4MOQzEBof4C7Kj3Sz8H","st_dist_04":"6R7ZsA9fy3TZsSeb9gNJiBHT","st_dist_05":"gDcVniTJo8rIBObYnbsiEFl6","st_dist_06":"H1qsRDxwtMzsRabByBGmXrOQ","st_dist_07":"hBtmzYnlKk9wILIl7LcFav43","st_dist_08":"7bIhUKAONlFr4B8ZgO14NqN1","st_dist_09":"xcaFjKKMNzx3kEjwbNdCg1Oo","st_dist_10":"yTcKkyZ9puHErQDfUOy6I0CF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jeK7IEnEO8ed8r2nApKXOSk3TR3tH"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739246,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1421,"st_w_id":1,"st_quantity":35,"st_dist_01":"XidYHbSYYfeOsLKDyCG8KhGO","st_dist_02":"YW2q8rSfK8htVvoqQz4S49FN","st_dist_03":"5bVOM1xElxWasA7ma5zamq4t","st_dist_04":"JvkCYgMe7FFIYhSehTxmWWHY","st_dist_05":"TdP0ELSJuV7E5EAuCJZPYoHY","st_dist_06":"P39eNeFzQxM9oQPvIwOPWi9C","st_dist_07":"fr570sCZQVSlIOwEM0QjoSE1","st_dist_08":"3vooALEhickCjfi00mrrScdN","st_dist_09":"gUSrWBCfGcx8641ezpJW5a7F","st_dist_10":"2PX1dwdxjhGjr16dFlNKQg8W","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"aoAPhJZeGpm8KU58Nh7EDf35Tt0UkMCgjcv0iBrOn"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1422,"st_w_id":1,"st_quantity":53,"st_dist_01":"yx8N2HlFqmi4ecJxJAm2oN1k","st_dist_02":"sSVAL9qSqslNTiaTGYXeToJF","st_dist_03":"U3CecW3b47AyrHZiyKNkwHA6","st_dist_04":"9hHwXmU6bKwNIcODRsrr0edU","st_dist_05":"3xcYynZGkrA63swKu1mdzcXK","st_dist_06":"2v7Ol03caO0BBaDI2RbWlx7u","st_dist_07":"YPMUtIt7XGLbj7dhQK5pGuIu","st_dist_08":"7j6FX5j3depsLgbSdBvXyObW","st_dist_09":"aw41rBEi1BOHdU21gmG5ZuYD","st_dist_10":"ZQREkIp93d5ILNK4xKGRIfNh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"WBkrN5K5UtzTTnUiXPoEuKl4aXXsWOoIdPWXA6FhUNQiYW"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1423,"st_w_id":1,"st_quantity":94,"st_dist_01":"HlhkUd2jm6S3f1pJ288sGL3P","st_dist_02":"oZmGIAEgrxc4GBpXsLX5sH4e","st_dist_03":"dnli7DZl9dNFDfebkDM1Hipf","st_dist_04":"iixAp64KYQQdC4MWKlXbnOCD","st_dist_05":"LpUZi4UjUYmwAby3T7wkWqbK","st_dist_06":"itkDqR4NgD9yshTghPTTriHi","st_dist_07":"QGRlXQU0WDrw1uoRNjFgQXP6","st_dist_08":"TElZFlhamOqq2Vc0C51G0Aeg","st_dist_09":"tQTPGdV7DY6ksPEjVfz6ip9j","st_dist_10":"neDJnoGM65F1RvBZQAiU36NS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Du79ESrqCPvWxu0vz4KeW3BMs9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1424,"st_w_id":1,"st_quantity":17,"st_dist_01":"ld052c4Yki23bvzZq6RHGjb7","st_dist_02":"0Db4YhP2lsJexAdfnq6rtlKx","st_dist_03":"PsaKOkTsvJJEndw7JUEa9xAn","st_dist_04":"8OSGecCaVLn9rRw2kpCl2HXy","st_dist_05":"0A2jl2y0reafkiyNaPfCd3jj","st_dist_06":"qobBTg087iO99CvrCFXmFocj","st_dist_07":"4Ylu1lbQCA4FGZPLyvSGXXh0","st_dist_08":"raPIpB4byrj24o179Qrbgos4","st_dist_09":"hhMqbqNLzshwYwTUAMnKh6mP","st_dist_10":"z71AxQccdeWiJnExRK9oPSYS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"cs1VC5oevsuFsdSRhEKtJVEosyhfHcRCcaowiypSp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1425,"st_w_id":1,"st_quantity":65,"st_dist_01":"PNWBSUw6OpzrZ5NZHN6Nj8SX","st_dist_02":"0J1U2uglnJeuSNdSAKApfmKP","st_dist_03":"2qpUn0sQVnV7oi95GW73hFgf","st_dist_04":"cOuh4BG3wMPnuWsWNEASjorI","st_dist_05":"C0sHWu1TariCMSQC4ur0ZL5g","st_dist_06":"7Nak9NOQ30iXRaTx7uZqh7Sy","st_dist_07":"PWPYdQaat83hqU6u0Nj2WPJu","st_dist_08":"8mUAQ8i4aPiYf1Dq7HzvXFC8","st_dist_09":"48nQxy7XKLnvIW5PFR8MoqaI","st_dist_10":"ungqn9JbNZCa7JBat9XLyQWd","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"pkoPZkXKQTI8viKnB3SWIqeo7C9r"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1426,"st_w_id":1,"st_quantity":19,"st_dist_01":"j68XWMVxz2jVRvAgOBKDyjOf","st_dist_02":"7TbZmfaLxo2wVAqM1E97plNZ","st_dist_03":"IjMhmy4nGjzsjB9hsJEdC7uK","st_dist_04":"r4ud8jcHxUfRolXNUbrrWIdT","st_dist_05":"D3dfnwLqTIYB8wtMQ6ctTfVY","st_dist_06":"R8JxtKwQ40bEX5SXUhZ1eLpT","st_dist_07":"PdT4PfgBxOp9ThymGLbJznaE","st_dist_08":"6xzihdKlVeSoi75tgCBXBsyc","st_dist_09":"Xy3XEL3C3S2gdmmLOh2vMGpx","st_dist_10":"yBEshzPpAICDNYWa2YJ83TN9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sVQTaB6GpwJvVEumLyoXCjg5t6p1M1vlT7IMv5p02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1427,"st_w_id":1,"st_quantity":17,"st_dist_01":"lQXl08vKiRfM0LFoCVCF6aJI","st_dist_02":"J3w1FNi6E6bnf6BKavIogU6g","st_dist_03":"8X9OOZtxs1ysuMZul1VdrmB3","st_dist_04":"QlC1yFw642oRrWFHzLJyrJol","st_dist_05":"BbER4bVTK9MXgZhrDrHf1twZ","st_dist_06":"6vXy3V2BaHN5sApH1NFQCPo2","st_dist_07":"7gxz3ufzzG0C4AQP7UtQOy1j","st_dist_08":"3MvDclqGBS5cVRID5CpUHB2k","st_dist_09":"IlJOTBj0WM1gNgvCSKXowvIf","st_dist_10":"bi1dlBz5DjjBDoKiJHTM85L1","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B9AAS7originalphXmXmupL567XE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1428,"st_w_id":1,"st_quantity":11,"st_dist_01":"nNSvqNItetWbOZK8TuQ1nA97","st_dist_02":"6EFax0ZsoZ99futGBwyaHJCm","st_dist_03":"UT8laNX7Wt3leMANJrKUx03o","st_dist_04":"7QBOMzslZtR2YK4RPhQIH0nO","st_dist_05":"h30fOKKZ2KgbbHjSKHivaJEW","st_dist_06":"jTqmPCAN2ZbYPsINyInRMNNX","st_dist_07":"Dx9dRwo40u48sSI3m1n2h6C3","st_dist_08":"KmgF2Km0Pas4maMVSdt8owLP","st_dist_09":"GqLrmknXCdGGjj7dvwyBAKw6","st_dist_10":"jcTzgBYemW8Qgd8CoWRDfA06","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"a7pctDVUfmp9da0qfS9i3PQEAaNlO8Qq2ii1wyehqfq94YgOVS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1429,"st_w_id":1,"st_quantity":81,"st_dist_01":"Ja7Q82bdWDQvLpt38Af6RowT","st_dist_02":"Das8LQyNZ7WW3YyDkpWCTsI9","st_dist_03":"iB6lwW3lGJIJLCzlBYHQxWwK","st_dist_04":"KhcwH56TRHTKD1M5vDVskDHi","st_dist_05":"0TVckYd2G9ilPBBo8N0sIM4y","st_dist_06":"VmF508V7vZCK0O5zWlysyrXK","st_dist_07":"6KDj0FUVBvfe2X5n6HZU6tEd","st_dist_08":"dCU0jclkx0kviWsC3omdA4vk","st_dist_09":"Mu4OCoQOpZKJqgKg3EtwrAIn","st_dist_10":"BSBmKEz0HrMWUXWvZtIPMuqa","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3PXGtwxIXFHnQHGxwfu3kEXeXU88bK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1430,"st_w_id":1,"st_quantity":10,"st_dist_01":"QvWo7riuHF61q2CjHAvKFFTZ","st_dist_02":"tgRx4ksXo2yXJcpbxSmqZezt","st_dist_03":"EfQNnO0W95wh00XV1tc5JQtx","st_dist_04":"t6t6nHHKIHlUvFfW4Y8Tt2OK","st_dist_05":"SPI1QYShwHmlQJD7wtzZhoMT","st_dist_06":"CEhTBC7IKg7DBCeMYYf4q17l","st_dist_07":"3QDCf75rYiCmSY6fucIeXeCp","st_dist_08":"gDRNDCU8Jf4fRQyEiqHQwvj0","st_dist_09":"9VJBCBJc0J5XjpnZiDIFh1bE","st_dist_10":"gne8NfvlAAxvLJKtxL2bwReR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ERd7Qm1XfSWL0wegsWRA5wjZm3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1431,"st_w_id":1,"st_quantity":39,"st_dist_01":"5GW3xMYNv96LazcqOZYivZu0","st_dist_02":"0b4qSBEac9RvF3oKYkaFo2VM","st_dist_03":"DJQGuIyXCYPzm3PSetZVGnU8","st_dist_04":"L4o6Hmp90y13RD7Pn6Cyr59j","st_dist_05":"cekAAkWFObey8EgbmgJKi0Rs","st_dist_06":"l29whSGixM8fWIC5lzLQoaGT","st_dist_07":"wsDOcvUQKGKLgiZZiJToUxgk","st_dist_08":"5VUsLkJ3aFwPKjiAJhg411JE","st_dist_09":"wSXT1OgngsbLGYQvEptvb3of","st_dist_10":"vGSGzwFj0EpPwIQzfqaH0ZKC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dD4BEWP8Wp02BSDibjbWdkQqSOzwPUDbSVXx"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1432,"st_w_id":1,"st_quantity":64,"st_dist_01":"up8sDuN64QjXfaCXXJIQ6LBI","st_dist_02":"lsghlvvoiEUsd5XNuNf4Lwe5","st_dist_03":"GMbwjDigASeFk5NDqubkXbZt","st_dist_04":"nwuem6bqgg4x1L2k2EkrET2a","st_dist_05":"DmW1QaEOwF3ooYfaqaLu6Whc","st_dist_06":"Omxjs61RYScBpy9JlUvzeUd6","st_dist_07":"R2FGmHD40tGRCipOLGNtz6I5","st_dist_08":"9IGI5stKhvLA5a6K5vM0UsT4","st_dist_09":"u8SrMbubYOzMCPEr1mngGvEW","st_dist_10":"yyAPKw5ngQAaiwFuvkQXMLBx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4qkuB2nL2BUCYXtRWlErDz3JFBELzxLKeamO0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1433,"st_w_id":1,"st_quantity":24,"st_dist_01":"2QWKR74C5eKwgEeDNPhpDXDz","st_dist_02":"JCdNQn7Xjx48j5uCd5MzWlmp","st_dist_03":"L2c6mJesagmoVnISbaVfWd1O","st_dist_04":"5w86qJbbIBI1lQcZBGFelg9F","st_dist_05":"RHBD7APwQ1m0L7MAs24aAq24","st_dist_06":"ONmyjAZ674ZYYx7WFZbqWo6p","st_dist_07":"CR9rRfzGblcMWMlmJ5aLotaB","st_dist_08":"K6ZKRTfRZxRb7CGxgRU0PYX6","st_dist_09":"LcH7yG8e44kX3DjsiPmOhJzw","st_dist_10":"wsuFvKJfb7yOW3UYWhp6h9DA","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YT2jbBWRnU8KILQQUe8YCugeKxP7sQ02L9Dbr6c"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1434,"st_w_id":1,"st_quantity":86,"st_dist_01":"9MZk2hk6An1bcFI1uujIjAjY","st_dist_02":"InYBhO3kDwiGWlYDyn2pHTBq","st_dist_03":"zOHa4Fluum7n0QJ344ZqvT8s","st_dist_04":"f3XRwejQ64X3Gj5Wd2jfud4R","st_dist_05":"xLJO5E3gvR5UjcQ2rGXtbQiC","st_dist_06":"VyDyXfkpn2GWKEWy1xM2rXRK","st_dist_07":"AxH3hrB9wHpsY1unoGLWleKl","st_dist_08":"kt3RZvP9bhAZJWR1j2V1yPAD","st_dist_09":"yNeLo7AxokYYuX0RPpjm7o6x","st_dist_10":"70UlOY86nbiGOyF24HV2hqIt","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"z9dZ6i7KnTmephkO2UNFdXD6aU4pCU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1435,"st_w_id":1,"st_quantity":63,"st_dist_01":"G6zcwImB6ZaopgVxV2w0MrJG","st_dist_02":"bJOer3EsXBjgCe3vL4Zqansw","st_dist_03":"5T7H0AFDzw1dVgkCaIfsMu7P","st_dist_04":"EiqcfNZbgOcxRDtFfOvaJuna","st_dist_05":"mdYSr6NIjQ2JvjnxuPAMWtiy","st_dist_06":"43EcYx6RRLDrxmtA4DzfGfVT","st_dist_07":"c2YbZ5g58sdGjnp3gHoVpbPh","st_dist_08":"garqVmS3Y95Od5JvJOCFQ7ZS","st_dist_09":"vVQAnVrJQ0sEdU8J5bFJ1p4c","st_dist_10":"giXNc60iGAUfpWLPOXcFCKo4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0QEqGXGghKforiginalMrsGRBTp"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1436,"st_w_id":1,"st_quantity":29,"st_dist_01":"fMX1mViRM9lCgReYaz6sdOXa","st_dist_02":"uUAo9iZPbPuGn4xJ5Guf7SVy","st_dist_03":"YgNkwiOcFmnJvAkmBPYGA9wl","st_dist_04":"0OFeqJqBGuuHQQXp7Taf5Kwi","st_dist_05":"ZakdHIAiTi9YoNAolr51VdJJ","st_dist_06":"y59wUp0F0iXSNRA6lsi4hTV2","st_dist_07":"VkMpK8ck4cRFDLoPizWjCqNo","st_dist_08":"u0h9OpOWoJTCCRvC6uANzGlJ","st_dist_09":"kJX6x67a2IQsgXzC6ui8Rn4i","st_dist_10":"aUxfRcwvQJhVgIIbvapNs9bK","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RYtMJoRBTKC1RtA6iw33ZiCp6qcTYXNufN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1437,"st_w_id":1,"st_quantity":98,"st_dist_01":"5IIkC8oHUbQHvX5UBf22Qstc","st_dist_02":"SjFontDkJxzC84yOwIz6RcHp","st_dist_03":"hlV2UjeunAOUJ9c77aMtVBx0","st_dist_04":"vQ9qsfYdGN0f2oJRRiFfAmmr","st_dist_05":"WMvSqwqfRmsdzPLJTRS2ODBn","st_dist_06":"HNUWvTE6vTwJfK4ZZ4BcuG1G","st_dist_07":"4EkVqenNTpTV2mftz323ECLS","st_dist_08":"BlD91jsCgrbvcBgSpcYrVvdm","st_dist_09":"urq4LjiIbpN5K8fv4fLRcZiU","st_dist_10":"SVmSuM4VGaKaFCQTz7XYiw6M","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qZkiDO4HgEfCh1uhxdmhlE6ilPMWtBDRMlSqoZcuqokxp9Z"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1438,"st_w_id":1,"st_quantity":61,"st_dist_01":"evAxB7yfnocLmX1No0BlmApT","st_dist_02":"clphmGasoasjdDFoZ59bqVZP","st_dist_03":"8aX4dNuhVguvvUoEm33l5X6A","st_dist_04":"iw6rQsLvBHs08ItpSJc2YJty","st_dist_05":"RyJiW0TWK04MQfTkq0Wkuzqe","st_dist_06":"mU4xPnRiBfzdElCYT4Dco1C8","st_dist_07":"9ZL8R7W8186foTIMLjhl1G8K","st_dist_08":"GiQut7BkTbn20EX4vkMdka2y","st_dist_09":"2qCxYdO0ar2iozDI3iJ6FOzl","st_dist_10":"8G6YeqLjkL6ihkFUiUMkYMDI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"nrei4Y6XdeuCwVUY03nQlyEFtrUviMMnc5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1439,"st_w_id":1,"st_quantity":88,"st_dist_01":"9742fpRyZu1d9Int4K232KJJ","st_dist_02":"4c16ZuSVA12vQeGMwroQxzLW","st_dist_03":"bfGUzQqieDewlT6MjRJh6gTl","st_dist_04":"obROXBbxaKYXU7KIRPwuHuqF","st_dist_05":"mnDWPrz6P6hgTl50e8BlTWGg","st_dist_06":"Egyid8Nx40k80GWUcbD3n4Lq","st_dist_07":"lifzC1nLkzRztxfeKxtiwTGA","st_dist_08":"fCwXTfwq8WLuz0mV9N3cC2tH","st_dist_09":"edgWaxzhpZEAEe31JW7Mynoh","st_dist_10":"a8vZqXJXeXqBRThLJFt2aZdy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ZJuf05jlCOm92zrjLE5Yya6mTr5qioXZmDcRjdZJI19TwvJ0nk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1440,"st_w_id":1,"st_quantity":100,"st_dist_01":"bStgvAK71LGa1KErguDt9HaU","st_dist_02":"5fUnUpEB3ihKQbmnGJE5mkgG","st_dist_03":"BR7TzFgmm4LI2XdFamZ74gt5","st_dist_04":"p4ZQnPO3JYl9QT4yZL6NUFt6","st_dist_05":"FuV7ScNOxBGJKUpEGfpoRiKR","st_dist_06":"oqoYQymmH8o1fQ401lJXGJTp","st_dist_07":"DY6wSWowarmDun8UurQVejHy","st_dist_08":"1QdxSrSwSpZjTU8j8SMvO4rf","st_dist_09":"FolMjouJ8uzoI5MEnYB2qlgV","st_dist_10":"UxMV5bAqHDxAOqjkovU1rVt3","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4xOFfgCiCqWC01L98bmUT9i5kHTDiXOoDOpc"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1441,"st_w_id":1,"st_quantity":68,"st_dist_01":"yq3Y7AtP0FxZUj6Qs2JTggy6","st_dist_02":"s3r4MQhKAAwiBadlp1VS0Mwg","st_dist_03":"QVVn5Vd3WWYT99vBkaWE6wxy","st_dist_04":"AQDnEgoGD9Ni4SSFwU0ZWTS6","st_dist_05":"Jhjfm9th9hVxO8bSqjuqo0TF","st_dist_06":"AvXflCDp7xVIQSwZExwjr3zR","st_dist_07":"76ufjEuAMkLQnhhibHj926R9","st_dist_08":"bqH6MOAxsfDbYK2TalAQJLJf","st_dist_09":"UNV5pI4GbjWdFaEvehZHpJ9b","st_dist_10":"cGv0ixbe1TvZvqDuOwGXh1Ab","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PNslKZL4YN8Eo8kXICf3PaPDqKtlMywPNFhb8BgfZHzprVi0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1442,"st_w_id":1,"st_quantity":56,"st_dist_01":"mVFNEf2IbxrSy5y8AVjeZajv","st_dist_02":"769Iir4W9NvL7zySXndU6ENp","st_dist_03":"nYh8vc7NT5vL6qFyO2IXFY4b","st_dist_04":"ZrfgQPCdjSBtsR7G5Fu69pMU","st_dist_05":"XRvPCtXFOcJtnGxiy0PcjR7b","st_dist_06":"dwhZBtFWlg21xoH4Kc0cTH0V","st_dist_07":"2ow5dt9Kqbhhp25dhGXbw7eK","st_dist_08":"rg7nIzs6grszegMr4sYVvbOJ","st_dist_09":"Dgj1AruuViASraXhOvGY1vh7","st_dist_10":"19u9hs0avgKhTY6OoJoR6UCx","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"YnSAqAepZ8w8DNDM6Nt3oQAvJ7vQBtSoGfegHixOJXU"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1443,"st_w_id":1,"st_quantity":84,"st_dist_01":"liOmJxGI3H4PvPaJ2wiu70zZ","st_dist_02":"pRYPD4KrGzseEyTIBQqcnJcR","st_dist_03":"jZlSU2JEhbu0kf6DMyUQDTAR","st_dist_04":"706PUEc8wyybcFS0s2kJzrRn","st_dist_05":"WX4UPhOehyY7Kx47AWxif7vx","st_dist_06":"LTTobwDF9b5PUzlrCcbhykRh","st_dist_07":"GP46tCeGkYneYzoU8qsCh6EL","st_dist_08":"zbcidc9QN2x99PjVJuqAtxYn","st_dist_09":"RAElAZNfEsYNF7uPs0ZtAcNY","st_dist_10":"P76lYMTd8OoY8jWzPVjhiaSU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9yCtyBafXt6LSS8FSV8MI0LXc4vYgBsKtfk2iIb65zgny2Kh0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1444,"st_w_id":1,"st_quantity":66,"st_dist_01":"gtAt9jxVW3axU4X7Ub0i7XnK","st_dist_02":"0vArCgN62UQTnNV1JEbAIt4N","st_dist_03":"SQg742QTL3ZWAxfEnnPWFPCF","st_dist_04":"JzT4TFi62Fz7NG0Tk3i6zjfS","st_dist_05":"dH5k1egxILVvR1pBeettc548","st_dist_06":"2AMabNyj1ndqAZPd9GFvS1Iv","st_dist_07":"zQ4wtukQl1LrUj1QVzQCTvAP","st_dist_08":"mb8z6nL0Irj2bFFEi4NiQCDg","st_dist_09":"cE4AkZLaH7OOF66x3KrbuY2p","st_dist_10":"KXpHIKnTIWEjF3Dvfb5BAFKW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"choBpVoriginalYO92WS3llt3CMjLRzG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1445,"st_w_id":1,"st_quantity":70,"st_dist_01":"eQVphZv4SQWeWktSsxZiovjX","st_dist_02":"YqMoCQqGzx0HRV2hVbeFdSZh","st_dist_03":"egwVHbFu1Ewj1kAvTaTUBAqS","st_dist_04":"a5Xtt38j1k9tmeTyzSHwqRD0","st_dist_05":"fdzkm2ig5U4ZpsnGn1cWMzTf","st_dist_06":"bvBxi2cpylJrYfwS8pJye2hU","st_dist_07":"5mWvGJ2JYRMVK7RplKuCDuAQ","st_dist_08":"uuBg1ymTEDdXKxqehtuyFIuR","st_dist_09":"aqm4lzBNvMwCTP6CAO8spPPp","st_dist_10":"OxsVvke8iOyQPH5zcPAWnhZv","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4rv3szMjojD9pv3V0k7QNRpbSIFeD57Tx5dE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1446,"st_w_id":1,"st_quantity":80,"st_dist_01":"VbEo0QCZwcGSvgt3gw1vdCMc","st_dist_02":"1Y3D6qRfWBUUUZ7osNkxw4sI","st_dist_03":"P8TpggUPjcw66ToSbtoxUz9I","st_dist_04":"S2k5UTpqrvQJwVUuYcccAYpB","st_dist_05":"ttN6U9cqqviSx7T4V2vG0kQV","st_dist_06":"3PRHMo38XOwYvfqFoI807A7v","st_dist_07":"bdBIPToQ7BtBrPfT8ePro82M","st_dist_08":"lv3b29bRwccAc3E1JxPfuuxw","st_dist_09":"HGQMROEAC0cdKvPi8e3JuJNx","st_dist_10":"TwTtzj24eyh4Kla2F1mDDplq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ElRBAX7fnsbPbrXpRbivhhmJYVkFbmvzeXft6GtBH0x0UPtA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1447,"st_w_id":1,"st_quantity":93,"st_dist_01":"2hoQOJ4L5z1FCyjxxFKZWXFM","st_dist_02":"uZtu4ZnLsZESW6AuZSJkTbyP","st_dist_03":"w59luNcl3Gv8nbyJsDlIkjTx","st_dist_04":"00p4TxVWmnA2znhHLyuDEd4w","st_dist_05":"VjhGOoLAav1KLrA8opwt3Kgf","st_dist_06":"Sef8R8DLyd6maG2tIjwsnaH8","st_dist_07":"cYb5HAhdLv24stGjj1eMAh1t","st_dist_08":"cLUpBnt16CQ2OJCyhSoeNadZ","st_dist_09":"ubujnchGjOVQtlOKPvtBb94G","st_dist_10":"IG2fUOofdXBolICATJgpyFnJ","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NFLPrWiuwYFzhJk7sdQPN1aIOLamI6vQv"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1448,"st_w_id":1,"st_quantity":35,"st_dist_01":"Bdi6K3smyJ5XKDD2x4rhozev","st_dist_02":"78GgXrsorOJgKEHo45uqzuOE","st_dist_03":"4Qz07Pf4DqIyGURo9fR1SQQe","st_dist_04":"U1jgFdj7epzB12olE8J9tPyw","st_dist_05":"1uq8sJZWM7GyVVcwVizJMIuN","st_dist_06":"LlFMwXeIeeQDNIvMJ5WCKUiS","st_dist_07":"uINx3FDc8W6seOs3mXcW8Yi1","st_dist_08":"d5bb37Kg2Pq9sgDrItfjkgXf","st_dist_09":"yZKUV7GC6ZEIhphKMfP4fDHl","st_dist_10":"FDu7RA78BkrMOa2aDMZ8Inoy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Sk9wytYjKmFbav26PPuA1NyJrmXfCEW3xLVM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1449,"st_w_id":1,"st_quantity":81,"st_dist_01":"IJd5IeZlFPk7125IBCk88Upb","st_dist_02":"l7ekO1eZcQWKyiI2RFncSY0c","st_dist_03":"KjQs4nSQBqNXbyjZIZh5NROI","st_dist_04":"k2jg9sa1VOPbAX9Ad5HXLgcY","st_dist_05":"GA4XOauwFyYWZsFhJ1zn2mtX","st_dist_06":"nUo1OH3BFtufgMeMOKUbbBTc","st_dist_07":"osgm36DbteInGjsV7BATLY0u","st_dist_08":"AYapISwpaChFfejK4CEAk4sp","st_dist_09":"7A5igd3r6SUBDbvMTXs1tO1l","st_dist_10":"igQ9tonidRhLARhvikE1T106","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7UvMF4iUvxEXcTelnpfiXEErnzjAUOBbQfV7ft9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1450,"st_w_id":1,"st_quantity":35,"st_dist_01":"0RCGMN9GnkIdIxY9kF0y6a8L","st_dist_02":"4Lvv20vZ9eEAfGTCGs8A1zth","st_dist_03":"RDfDzBNU9oOTQUtnMCiJn9pW","st_dist_04":"lLBdy288eGf3MhWC7ogRJQFA","st_dist_05":"onprj9nxaPiH5DGguu83UkLY","st_dist_06":"gftTl03UQMZOgkNtFZroJ85i","st_dist_07":"iI5roQmhV9Jrjp3bEDaamyfC","st_dist_08":"wvDJhjKv12q7wVdUtHc6zfHB","st_dist_09":"fHtmrlte4RaK8MJa8NvtXx7W","st_dist_10":"CkXt9oCHoxjrfa95yhQgM9LF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"AqdJxjWQuH9DIOub5RIYMTXuev8z2v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1451,"st_w_id":1,"st_quantity":92,"st_dist_01":"9CohBZuuh0ONuhsYmGfrXmfc","st_dist_02":"ksX4L8CB0tU1aSqhMGwkz49L","st_dist_03":"5jw1U8skoMptYUmnrWIeBkxq","st_dist_04":"6rYZl7lDk27omWPcCgXLGK6m","st_dist_05":"hGZHQJ2PjOAZQwWcP6vybEK4","st_dist_06":"EoCoiUS9NRMFwJHU3qzNSr7T","st_dist_07":"EWzIn1LyP0aE8aDQAx9XGVZZ","st_dist_08":"W4AKYeP7iUuIBFtMjGDgT0CP","st_dist_09":"hawedm8gUBXIfEzOsJMXrOtn","st_dist_10":"N18QIglRZm2OlzGMdBb3b7Rq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ix8yuNk0nQjMItMohVnKumSsXWoriginal"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1452,"st_w_id":1,"st_quantity":98,"st_dist_01":"HDQcBYgjchquFgHhAoiI3zhL","st_dist_02":"Bzgn8LIFQ4AGVkEQCcOSvJWV","st_dist_03":"d7IJHvEcPW2Kc9jRI7l0rQmI","st_dist_04":"7HdItVpXpulgRhWjeiW6MupP","st_dist_05":"UVD0wAjYtnRf9KP7dPKgDYrh","st_dist_06":"gIHJNN06Anfx2v69u99jM8HO","st_dist_07":"ARn4QNkCmBUCMS0V38frHqvr","st_dist_08":"IFmvktGDPTFCB4mkfu2bvQeH","st_dist_09":"JhVibI7DBYSkpo79dXJBQTl2","st_dist_10":"o0dQoShWDkYzvMgqGgN5zgvh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"FJN3YZA5H6FcDTlhudkTxRKtvJWjLL5nz1mByK018TA43PjGu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1453,"st_w_id":1,"st_quantity":85,"st_dist_01":"FDkFDLCJgMyt12HbFSUVfhzs","st_dist_02":"JWBIGO7ecL8HZ9PjcnnEzrOr","st_dist_03":"ojPg2BXLBjfkpZaYWTzNIF9n","st_dist_04":"ZNmlKnBfLjnfYM2Hcvh5vtmy","st_dist_05":"xzZqa1D5xbNC2BfsWaXo7SlY","st_dist_06":"EaYny1Wpnyit7sL2FDIoPAbV","st_dist_07":"u5N5plPoTFTT1XtXjwAoTxVq","st_dist_08":"sxhOVddZLy7JzGzdmb2CRwpx","st_dist_09":"WwlNoaUIrH7ETXYCgI0yxxCP","st_dist_10":"o6DuekU4SB2KJxALqY44rCdu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jHrWa1ScQOya5XSEzTbM5ldmgGhhwke6xLjxBxyFwuhM"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1454,"st_w_id":1,"st_quantity":54,"st_dist_01":"cnXtXNoF3v6RhpV7TOpKRwb6","st_dist_02":"1hXvmcuqOR2oA99LMzapxOMa","st_dist_03":"eYBgH53dUB91c9wREw4PUzAp","st_dist_04":"FsgoflShQB2Ib1bMzFlFHLcA","st_dist_05":"0HVbcL7uXGgCIzbUaAenZM3N","st_dist_06":"ojrGeXti4aaaX8jHfaQRJ22L","st_dist_07":"p9F0tOJssTHpV78rvqqX3wBh","st_dist_08":"S3mkbrlD8xL4rUtdjVfpz5ys","st_dist_09":"BDHpSavWJU7pDgjTdVWjQcTU","st_dist_10":"50DUdsk4rMhUVEnDwyChNkfE","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"InAO6A2Gct6zz3wjbnlLjYDRz8aOoTECSPQGkrPFzjTYKF2X"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1455,"st_w_id":1,"st_quantity":62,"st_dist_01":"Ri9Vaa6oxNj6mgN6PC1dIu71","st_dist_02":"o5kdDq9stZOgkLBcoRX74Wzp","st_dist_03":"7CNcNvptVd164KiTSnTj9yn9","st_dist_04":"YvygmbVoaiINODexo5r8U7N9","st_dist_05":"stc1tGbqg9RcEMrbMY04GwnW","st_dist_06":"L3HgcBXfNBLpYm94CwXyBG9q","st_dist_07":"L4ZxXYf4jssoeHnlaU9VfInt","st_dist_08":"T34wmg4HIu7OQQvzLpXVLqRy","st_dist_09":"KRov9UBJ8wkF1wN2tps1rm7z","st_dist_10":"3wK6O0SV4Sh6Hyi8ocaRkFbD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"s0vpZdx4fvPGe4GNCkmbyMPrisQ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1456,"st_w_id":1,"st_quantity":38,"st_dist_01":"HiOb09mqfhPPqxf9LmLVvUrD","st_dist_02":"INEO53MUiYfcQBkUU1adBxFa","st_dist_03":"f2h56oRJWpjIK6PVmWiUDOv2","st_dist_04":"PGS1nU4eztcaSahFtqaAFia7","st_dist_05":"RPnZN4gN5hhCQCed3FpK37HV","st_dist_06":"8eeQCiFApNnnFmb78QsAKUxE","st_dist_07":"qsOCGQ7r5X6vL6Gk1K7dNLm5","st_dist_08":"0H12yrIcnW1qsMXduYvLIVfN","st_dist_09":"18mHsvouwD2QiLohlqiV0w0t","st_dist_10":"2plIhMihfMCuSCAmsDDT8xT5","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PeOs933du6ikH68JldYU7LfNdHdpYKfG"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1457,"st_w_id":1,"st_quantity":86,"st_dist_01":"Z308m49biIVkLWNRtTtAJiyN","st_dist_02":"GW4fb4ooAgYu7jXHiB8BDpwx","st_dist_03":"1qTF5nb1sh6kAh4o8QYbtUhN","st_dist_04":"h9zVNf3wPUxPBNk9vDTwYopw","st_dist_05":"MW3JJLBElpg3iRJpUgciP9iz","st_dist_06":"IRSC7Z6ZU6ewvtG04TADutHe","st_dist_07":"0RLzuwbwn5qSEl7emFUvTsPl","st_dist_08":"QyY78M7CuvZ63tBu0YNBdfIn","st_dist_09":"IdKiUt95ZjFmHg75OxY1W8rD","st_dist_10":"BmjQtGEwigpTSgL9hqaFdOiw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"8HwS0HIIkLvT2DNp4WjHLwQnE8521sd5B0originalCz4A"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1458,"st_w_id":1,"st_quantity":71,"st_dist_01":"vFOX5OV9xMOzZ38GRQZoTbRe","st_dist_02":"wxUZeaLCcnYx7wOblfLJjR8V","st_dist_03":"6WP7NgUaPkwy2J5zxeHZ7HYG","st_dist_04":"vA2iI6raReZeQJhVUnszWaJN","st_dist_05":"t4Au9adjNK7KtTT1IAk0v0Wt","st_dist_06":"1hoIP6IwvvCKtbM3C0gSRoi1","st_dist_07":"cRAvP8Aor47n3pLgRu6E7fCO","st_dist_08":"UTPEANIbH4E4J5vfrIWbEUyy","st_dist_09":"FW3Cap5Ypf6BgLYZT7vCr9vN","st_dist_10":"ujFXowbh2V22llaaLqjUabNL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6EfnWtiDcM4d3r7cgwQdE1s7pdV7MBfo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1459,"st_w_id":1,"st_quantity":48,"st_dist_01":"sbg88FwruCTSZDiGc8N9gIiE","st_dist_02":"Hc5ZEBpJoII6LGUytHbcZnkp","st_dist_03":"xDulL3peKcCBOF6alUvZhHLu","st_dist_04":"SzIAn9aZugmOMDwsHaxxIbgW","st_dist_05":"02GSUojgcShjOfVG2q8Nv15g","st_dist_06":"pboKRVI2tGztW363laivrIyf","st_dist_07":"JeJqfHtTW6FLhUTZSreCc9wb","st_dist_08":"531xjftgc5VKZYQp5l6Epc5s","st_dist_09":"TpGOgJxHg7HOefgkEca8Fs37","st_dist_10":"ILF0WFRgoCggwTLSDzSx2J5h","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"S4ScrxBepQVcDYJPfb4DW9eDpKmdhG4V"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1460,"st_w_id":1,"st_quantity":64,"st_dist_01":"R6BFszzJR3XISNrnLJSD5D1H","st_dist_02":"4ROwtbIwdu8K32OFmDhf8s8G","st_dist_03":"x6BjI6VUKzgZAchiDkBg5YO1","st_dist_04":"2vPnknjwQt7NT7LJ7tr6Oq8c","st_dist_05":"2HIEqX9JHPpHWZvd7q7ZMZIq","st_dist_06":"GRJqkIKSgL4ECdKDW1Ofuzkj","st_dist_07":"1kJwMLuZeTXlKR00JLHazsNL","st_dist_08":"8plcB2hPThhH3oy4ZebEDkqJ","st_dist_09":"5F0v59Kheem27iYAcJifK9IN","st_dist_10":"SVz3Yy9iqxd0Hi7xm7OZUilF","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"J35pgaauguSfsPzKrp4WKVPc1bn3ietCnsEa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1461,"st_w_id":1,"st_quantity":82,"st_dist_01":"wDnjw5zxPL5tb0WNwOFQ8PeF","st_dist_02":"ELqWR2z85cV3xd41oqKaRFQX","st_dist_03":"AIM0TUAMYNhdfEK2oFx09IVq","st_dist_04":"Dg0FW3638oDZyYlb0vR4VxGL","st_dist_05":"p3Wr4OJTgOLLS8Cy9FbaSJYx","st_dist_06":"HY3fa07cS154OrYNfhljF92S","st_dist_07":"SUKWHxvTPcGGmJ9AJwymKYfg","st_dist_08":"2XIXGDnA6Ty8whm4kO1HJ8EV","st_dist_09":"Cr5GIW7NcUfAQsSs1I63dxoU","st_dist_10":"9ub9fPTi8C5IEBeaz3fPuDEC","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jiRfKSsMoe3EJfKLUQynEuSdfClaYYCVwPTHF1JFC7xz7x"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1462,"st_w_id":1,"st_quantity":51,"st_dist_01":"qtLGp2HG0MBGMG4Z2r0QyOx6","st_dist_02":"WXrK0p86FUC9tjLdMATPA6Gg","st_dist_03":"2o7scXw7B0RPkBHfOqXdSWrb","st_dist_04":"dWDy26Kscf9rA2slRbhDQfYx","st_dist_05":"OBb4Dra3gKXVo3W4BKh7hXfC","st_dist_06":"emYZeYUDHevIbFPOIN0mfmjm","st_dist_07":"4G3l1lZoJD6ifbXEugKxWgQx","st_dist_08":"Sb2ORvMwci6DficRkszTUYfx","st_dist_09":"yq62zlLhSyw55910VWcF7rsg","st_dist_10":"F5SYOQY6enjSdmu54zL6yqou","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"vLs5rYCStuEN817rYMKMKBeybD"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1463,"st_w_id":1,"st_quantity":77,"st_dist_01":"5t99VGgUecXvNwMD25H0Jeb0","st_dist_02":"33xQUtXujerUzp5PAi5xLKV2","st_dist_03":"9wCUS2jc3Z8EuKLf5saQehKb","st_dist_04":"heVibJoQ8GjBgGsFuDc4wOUi","st_dist_05":"BAVhzSk1p2dyk66D6Vhj027w","st_dist_06":"gYvkssDuwcJ1JHXRyMHamXBv","st_dist_07":"CkyVJThoHirPrp23ayuKILP7","st_dist_08":"ZprOPkDeF9ntd7PYJNbpIjVE","st_dist_09":"QaHjQOBO880TPlMt0sS6LI69","st_dist_10":"LyE84POMC9dUeAONhPrS6L3M","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Pv7h3HadBvMhdaoriginalEAU0b8glKmBJwYKiAiQRWA7A"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1464,"st_w_id":1,"st_quantity":22,"st_dist_01":"ZG4OyeRrrMun0YZULevq3UBA","st_dist_02":"yucB63D4QIxAQcgdfF0vIy13","st_dist_03":"7SUZFDozJk3tlFLdYPmrHOnO","st_dist_04":"wHSguykB39cgPlXWxTdcaqnR","st_dist_05":"Ul4FV0d5X6ds2rKtJcr1OTsF","st_dist_06":"ADK7XppTayB9lwBDBeBPKms6","st_dist_07":"RDH3JbTfVlLYA7UsGdKnnzOD","st_dist_08":"j5ebRtBPLHbFEWapHPLYtkQX","st_dist_09":"rs6VnD58wIKkD9jl9VptRZbm","st_dist_10":"souMTTYhoAfQrG1U9mZ4S3ka","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0gyQ1lYTNobmmKNBKw7JtCXEFOMUHgqMslkQDz6pOYrYWeS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1465,"st_w_id":1,"st_quantity":25,"st_dist_01":"Slqi5bSPH4DKguuNQw40alhX","st_dist_02":"z5SD3LohEaxruRa9t5Spi2pP","st_dist_03":"ow5YkAH9B6F5KtHVn2yVi4pa","st_dist_04":"9livIICbQLzBKwgTDtH7kwxY","st_dist_05":"aIPieeS3RwifpumadBajvPVX","st_dist_06":"g5h6Xx0h7pWCIDMjL1kUJzhn","st_dist_07":"YYC3E5yY6pLCH6oOjD1hihql","st_dist_08":"Aljllqat5yZ0NxuotHnTanYe","st_dist_09":"JvZzfP8QAW0IfQarScNL0QVn","st_dist_10":"tEYs6oLqvoIdM9f2q7jFWQ7A","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Nu8vgD7pBzfaE2zXK8rpd5Ip9dx33rQVNfO"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1466,"st_w_id":1,"st_quantity":35,"st_dist_01":"B7HaNcEPwlGv33MRIyCBFdce","st_dist_02":"jskwF2kuxvXekSnk0Y3mOkCq","st_dist_03":"lzD7WYA0X7NcTQQM8P4alOFn","st_dist_04":"CPz0IHFhJIgIBIMrvIoWP356","st_dist_05":"y5CDFEcC0RUNhfmaJjZdqgAr","st_dist_06":"yUfCGH9JWmNDhGk5iHfv62iQ","st_dist_07":"wQhBDhGyBB5eCxvHfQiJCvd0","st_dist_08":"g82sLO4WEhvGQhefv4qXFOaB","st_dist_09":"HFNhFPiVJhIJFWhf6eZQmDIC","st_dist_10":"mGufMnVxbZBqYwHhZbeqqFpW","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JiGBFAb5C5ojTKRmBREoriginalwR6CF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1467,"st_w_id":1,"st_quantity":79,"st_dist_01":"RHz8uL6tdZwyldPKUf8P97HJ","st_dist_02":"DINOEVlWy7MkPrNlK6jfN4MJ","st_dist_03":"Nq59VXOxShQwoY0kq2unTcwf","st_dist_04":"VB7VRVFTBRn673SNlE3THlG7","st_dist_05":"GXLZXQdTXj2t0TOYyuSriOpQ","st_dist_06":"DBauesbKIFpDeEDD8tsgjgyv","st_dist_07":"gNgMNvYrwzfioau1sisMHzcn","st_dist_08":"xJwqGy36Rvo7Btph3rFVUuUy","st_dist_09":"ywlkGxwvhaeakWYBctLi2gVo","st_dist_10":"fGlV3HZeXeT3FAmXD3xMgFkq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RW02UfnjCQU0HToDymJLLsJdZKe"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1468,"st_w_id":1,"st_quantity":89,"st_dist_01":"OlXRQhTt2X6egk0S6YYsb5Fc","st_dist_02":"uB26p7prtwllmJRh6CCM23YB","st_dist_03":"Aq3NRu3dY5XxxRfYXJ5DHCCX","st_dist_04":"I4DwPZKVoLta5z04qwBNPONe","st_dist_05":"c0L8AJgcLRshPm0icro0YcBF","st_dist_06":"dPwO7arLUdlfo5Nbuop2sNTa","st_dist_07":"uj53XbYvLR1N2ImUMTFrDEEo","st_dist_08":"r7uvnyS3o8jL70rsgvRcCSEn","st_dist_09":"5WhQXLIofrSslgOa11XmEvfV","st_dist_10":"zVVZ6Td9XACF2j3B2eGOpYW8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"d4CkfFkbQgFbffC3mx1l6AjF0E09BWwwArs27LUOO131aiefr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1469,"st_w_id":1,"st_quantity":88,"st_dist_01":"bFFeIwMccJA5XEYLDQewp4SU","st_dist_02":"BkZpb6SSYc45R6IIXpdcXadp","st_dist_03":"8xm9GjfS9KGlLZK86qsAMcnw","st_dist_04":"kE085Y8MEOofKQUFcyUjGttj","st_dist_05":"om2RJ18dkcVk2g2dDqVjJe9Z","st_dist_06":"XWw3uCGGI4ElcPK4KZ557DVq","st_dist_07":"ClJJ2WrN8MoUOTYq6PDBMRSf","st_dist_08":"uQNIO9SUciMOo68XKQsqhiu0","st_dist_09":"LdVrLEJFqXMupofZksbzUIA4","st_dist_10":"YjMfs1N55Pj1rmPIUsjbRxMg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"sR9DVowCQ7ZOtT94E1e8FRnUYXeoriginalduJyajHZ0Wt3T"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1470,"st_w_id":1,"st_quantity":69,"st_dist_01":"wT01rNxpke6GIggagt0yU82Y","st_dist_02":"f4lZWnLYerBdcBvnQjGLqXqM","st_dist_03":"tPeaqVHF2at5Tgm8aCW6vQdr","st_dist_04":"kSMuf1pX36OyN4nNRLWOlbFj","st_dist_05":"tM8XGd4g3IYKVDg0u5CDCm20","st_dist_06":"gF0K3PN3pRPW9rJlBkwvMwCT","st_dist_07":"VqSZUJiJRHHHWfNu3lNEq6rg","st_dist_08":"ETeVFILtMQf9tnMeDGktDPm3","st_dist_09":"De4IRZBfNZLy8kpRfcyGuWBg","st_dist_10":"DEZOL8UP5UL1vBaCGWgkb06Y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JhrHsHShwLkeOft6xQD9wSYtKlND7z8AEJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1471,"st_w_id":1,"st_quantity":51,"st_dist_01":"auRplBV0XufxytYR5AJG1olT","st_dist_02":"W29CSyJ2Qtsg8bAcBDIISkry","st_dist_03":"umQHn5yfxythqje6zx1WkKfU","st_dist_04":"8cHIlJ5pA9NWNZDS6jOnafQ7","st_dist_05":"CMuOuSn2UZ4BjBAs3MKPHTsG","st_dist_06":"x5jjxTjiyEojaz7PN788zLQO","st_dist_07":"SlVly07cainGXp29HxfJvNKy","st_dist_08":"fYKrGxLlxUo2KN0TLHkReWZ2","st_dist_09":"HASH4BlR4SkP6ArifWyHGZg3","st_dist_10":"UKOhzjQmm2qu3JuI2ScpL5Ix","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jsfXPKh46fRfhVsCniUiMwKWo4dStgTyGkakbsVhf"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1472,"st_w_id":1,"st_quantity":85,"st_dist_01":"lqSwvatnpPIYdRqUsC6dNO6F","st_dist_02":"en1uJVVNpylg3tAY8ygvh2Up","st_dist_03":"8sqGf73CEEMLu2W55QVNwJza","st_dist_04":"zmUDYXERBAHmgfEoNuxvXy9d","st_dist_05":"RKSaR5V08wjxcjow5JDI7ciR","st_dist_06":"JxeBhyMIJ1uutMXadqm5BZCk","st_dist_07":"hSMuMhSCvxmK319N5COM9huN","st_dist_08":"DRErOxm50CPfnOJpDntTLcQr","st_dist_09":"iGcGUjR6ohze3gijX8ro575F","st_dist_10":"U6usSbyV3UagcWNQnN4qLMjy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"fvlBYlBlDc8JwqZb8BNtOkquDNj7UWCEwvVl4bJkNl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1473,"st_w_id":1,"st_quantity":14,"st_dist_01":"xGuAzyuvkv0hXMq7t7kvuiaR","st_dist_02":"bNPD26BB7IM5jho3V70S6Dza","st_dist_03":"Sb7Vzbuh90D8fxCm8AFO5WaB","st_dist_04":"chn3tQa2ao5bQIoyBPnjrAtS","st_dist_05":"slmsBG8dPkacjHWM3lzoYYU4","st_dist_06":"rrmVJ9imeM8hXmzRBKuY42Yy","st_dist_07":"MzySbKgCb0DJwYLbfEreuQts","st_dist_08":"dxXxbaO59rCUBDeOpfvNQDUZ","st_dist_09":"7OgGVFIxJTLb3HRW7A5omeWM","st_dist_10":"t9AIAlu38VfEeFnFMZWpQXeU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"VWlU7YoS8dhkUJkh9KXKQitDmx2FQQUgJQCVp01JP6gKy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1474,"st_w_id":1,"st_quantity":67,"st_dist_01":"EeQdviCf7Zr0WDmzVocF7FMp","st_dist_02":"5NweO9M9ujlMtwtB5g18dLGU","st_dist_03":"plk7KokIU7VZquFXwfI2pJGl","st_dist_04":"9WerJLp8Egh4Gpbo0XOcPlxR","st_dist_05":"JreHtTHlHm0628fMiEtrSOMC","st_dist_06":"595U951qFF8x4MqTT6fNnUsZ","st_dist_07":"elMGnjVWlItYU9WU97XOrcuO","st_dist_08":"7WUtyUvef3aH0xi9pqNpW3Zz","st_dist_09":"pqhK8E0LAvlfHPLxai6JwCCl","st_dist_10":"JmqahPpchoxuilr7lyLNzKBL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UUOTC0PmPfYb2G7W1NCsDP2tpVpNbd2k8tkEO3pJYr96logqyr"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1475,"st_w_id":1,"st_quantity":69,"st_dist_01":"m9QKCwqrooOJSYyOB9Jcxws3","st_dist_02":"zuxwBmnIERDzIcVFCoxCCGgo","st_dist_03":"bKpjJc6esVmt0cLYoJixDqHI","st_dist_04":"36wQ5DxUR7yId2SRVNrcBHM0","st_dist_05":"H93gJXSYZr8UXfvwJ9ouNzUg","st_dist_06":"cuPI3y3r7SgUJAzXi4j6cNV0","st_dist_07":"k9LICfYPXChGjTRC1DEdSYgx","st_dist_08":"P1Zp7KyOeZ63RvYvxxPW0UuZ","st_dist_09":"wepXi64k81zJxZRWcWCb39jj","st_dist_10":"wcqZMim5QlUFRxs1bUTTvXzS","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LScOGfmaoTsVaZRZIDT02NR2kecjSduUA3hZj7"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1476,"st_w_id":1,"st_quantity":28,"st_dist_01":"0EoZIxUxuRGs1my1JaqArMRN","st_dist_02":"RO4MDbqUUAHjQ7QyKVMe1dD5","st_dist_03":"y6u7vvRWcTdnDV8tPcG1HyKS","st_dist_04":"M1vC8dxrDWfU0lTVifDDk1ry","st_dist_05":"G2onlZ6SSwuEF2p3KPtCIGTY","st_dist_06":"9hnl2FMgGatXY993nHHwC2Ag","st_dist_07":"xb4HZSKHWn3TMhuBGACjXkAP","st_dist_08":"FwWbXEycPByu8Y29R0hoxCj0","st_dist_09":"3d129Yu0Lpdtwfl4sjgMwct8","st_dist_10":"JO7fzFISB8cWXfit2RDBbSaM","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qjXiQuwZSW6h9PaqbJ9wP6yqRoh1QTmhHwvQP2lWr5vt"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1477,"st_w_id":1,"st_quantity":33,"st_dist_01":"cDA0okJaBf5koo8JopCDe4wf","st_dist_02":"Cjwj0XVFlWO3izulGxQljo4T","st_dist_03":"qkTnzRuRL9bmHHr5s2NwL4sZ","st_dist_04":"x3M5cFfI4cdB87SpHGt1EAE7","st_dist_05":"K3eufFnKxtkHTBVupOlYJVgj","st_dist_06":"TZIu9mg6ZVSf3mryJQgUIr3C","st_dist_07":"I7kerviHumkCtAVNZsdQhXCo","st_dist_08":"Si8wNa63hdmijWlg4ySVXXD8","st_dist_09":"w1Rep5LjulPFoIY5dxwasEkM","st_dist_10":"yRrBgZ5nDIv07lgNkzMEFMkI","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"KM1xqsZ6TI1l4dW0xKhOc4ho26skj1iXcHsgPBG4Xhto"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1478,"st_w_id":1,"st_quantity":87,"st_dist_01":"PFaHfym11REY8S0xsxF6AKdV","st_dist_02":"JJ8VecaypJwBao4tmIgwyeLA","st_dist_03":"kbIcKiYUAOR5ork6dRRgKaNZ","st_dist_04":"GIDx1a0VQ4Z1cWoRZ01rwph0","st_dist_05":"hlWvdsYEH1A64d5wYAnbPJ6t","st_dist_06":"0r2ktfgFLpZm5ULFPZLos9RO","st_dist_07":"aIA7VY56EeSxd5krLzYqiYnA","st_dist_08":"OiCfFh6B2WOA8RaGAFU3rnv2","st_dist_09":"xhjtLQUEJ2sU2uh66EQJ7fuy","st_dist_10":"OqQguhJ0VWOvz6foKauhBbDU","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"JNyIbHAQUTK4hSepmQOBcJBCQyLASm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1479,"st_w_id":1,"st_quantity":89,"st_dist_01":"8ol7EejxsmaOv91iqaiaLCpI","st_dist_02":"OFrQrZaYRrH6l5LOezxTUlLO","st_dist_03":"kdQtfjxFyY46FaG6b2l1mRrV","st_dist_04":"cclomBITLMTbpbvpgmVqcAFM","st_dist_05":"HApElpQfMtPou3svdGbC2TmV","st_dist_06":"50q6xGR5b9ObKda769orYTHf","st_dist_07":"J9yuCpmoQ8GzQ3IBB1ogbxhm","st_dist_08":"NtFelPmaOzktH3TLOkqeb8e0","st_dist_09":"i90NSE8aOXKFmrrDDcr2UPGw","st_dist_10":"i9ep71AtvHswfjFdBcHHm78h","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5aaEfNaNsohHKOqoQhBgcR2rMsB89MDcWqXgDOGX"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1480,"st_w_id":1,"st_quantity":55,"st_dist_01":"zOE6jHwT2gk13uBq8n7kmhkY","st_dist_02":"5bNdiMtbKyMm2cOlVm6zvfon","st_dist_03":"kW85PrSsAiJMMju1dAFrHvK5","st_dist_04":"EWOaC8LfIPTBDJih3Nynh0LY","st_dist_05":"L8N6Sas3bSOIpayqT876HDJy","st_dist_06":"n3Pxxb2lhAtoJtrAvGQLozV7","st_dist_07":"zapqUBnnXKupLAjpDUSFljXI","st_dist_08":"4MUY5dN1f1tlyO13J5kmC3n7","st_dist_09":"NWRMVWIE4jNdwb4OB1toXAhN","st_dist_10":"uvMsiuUbjlqANjW23ATLesxr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"jB0hiaDRFO9EhCs609SUo9F1fuHBTn3J9LeOdCB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1481,"st_w_id":1,"st_quantity":62,"st_dist_01":"6vCLpjp80gLcnSsJi5GtFGYo","st_dist_02":"cRpINkWXVJGoeYau9HHOHdoR","st_dist_03":"vkxDZDh1DYPAdyfLxirb4Yaw","st_dist_04":"mCwMSmy1vyTrKLvh450NpGUZ","st_dist_05":"FMwQw7BNVgytl7pDv7aaqmkd","st_dist_06":"v0JwAZhF9GoRccl8OjvumufQ","st_dist_07":"zsQDfmSHrSMOtNKSVf2rCoFa","st_dist_08":"lQJrIhHlEHw1NeE38sG5B6lg","st_dist_09":"j3tBjsLahdgZv5sIdP6ul4lQ","st_dist_10":"mFoUb62P49j9cpPNDSs7Ohh4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"y54FRjrOvsC3Z6T5y0Yer71szUF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1482,"st_w_id":1,"st_quantity":49,"st_dist_01":"lFzDgs9GvFMILZmdId76YNUg","st_dist_02":"RXZXr34gc0XaLHU8H9KfBtNo","st_dist_03":"ikwwzhThaHoWiCAR49Wnc2jW","st_dist_04":"9Q8YZaoGUOkMWtseI2uof0gS","st_dist_05":"DHtseRea9pc4hRcSbr8YRAMH","st_dist_06":"zrG9AYd8oz1p3aAoWNH3jfLU","st_dist_07":"Nj1bD1CXvHuhBmNkcaPkJCdK","st_dist_08":"G4EicmWh7ZPyknm82M8t8CDh","st_dist_09":"2JgFS7EKHSy8hB9DwvJOjDwb","st_dist_10":"4BUOGpjsuutp81ByKjrELXEp","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0mCadMNLwQNj12qDXgzEkQoUm3EwcUuq9Aol44ETa"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1483,"st_w_id":1,"st_quantity":79,"st_dist_01":"xPUy5epVgMQjbmUqH7QiKtxt","st_dist_02":"5BmFH68hDSVKHbqQXWsITzWG","st_dist_03":"ZoLPlJHH4Qorm89vfZiIlPyt","st_dist_04":"RGKsVRe8UcGv96FC7PMvgIRL","st_dist_05":"RBDI1yZvGlyste2Hg5OVZOgr","st_dist_06":"PPQGiR4WJcOPX5GHxvAjkZCw","st_dist_07":"4fodkmXS30ZHe5rjcA2Dujly","st_dist_08":"TLSYUEOpOZOL28QUzBrGHzEl","st_dist_09":"sgNsPKV48ZFmrU5ZaHS0F5f1","st_dist_10":"AlqeqegJOMToSqFD6bDHn50S","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dkm44fXxw37YxT6P0GeqH2AzyEVnX3QGEHrhfzy8STlCl"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1484,"st_w_id":1,"st_quantity":11,"st_dist_01":"OigeSQgLQ137pL7r0PeHNIPr","st_dist_02":"wLLI6Ylks2wizCXKP12o2puN","st_dist_03":"aet4my3G1yl62ilkC8viKW2m","st_dist_04":"mOjmSKgcPoStZ1maSq8BWDzI","st_dist_05":"Ir1l4qmQIbk4TvCVxcgH4wcP","st_dist_06":"PiT5NvuuRWlvBw3G9Wz9Luaj","st_dist_07":"yMedhiwH88igz1OwJcNTln7o","st_dist_08":"HETuIfqlEQvML99T69j47zsH","st_dist_09":"fmjawNARqUAD6eeafPRsKtyS","st_dist_10":"Azznbx3NwZxG9JxcQ9T678Do","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"J4NuPbnThHoGi5u8kVfWNTEetN4RO9JUDDESn3HF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1485,"st_w_id":1,"st_quantity":21,"st_dist_01":"lmi0pM4O6FjCidLv5xwJl1Nu","st_dist_02":"iYJezEqbgwgcWbkYOhAKa7jC","st_dist_03":"bE6PURNQLUKOOYHNDsPRRuBx","st_dist_04":"QqlmAGIAQlM7sLgdeilJn3bv","st_dist_05":"qkL9iuV1PwqiDzLSBodQuZrl","st_dist_06":"dmtBlDbAGXLoSCjSz2ebfBlc","st_dist_07":"42NqHiFcmBDfCyJFZ3Zn8z33","st_dist_08":"9PRzmexDTfVodzALiEuVFSCG","st_dist_09":"79rJVIsIRfxMQmAZH1bYiihw","st_dist_10":"w01JCH37c03DoSLTvEmp9xqq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qcUttcVINIP9vQfJNNyCjmR7kAiYwnEjwHy1eFo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1486,"st_w_id":1,"st_quantity":13,"st_dist_01":"qlMu1ArGzOgQP1pD5P8mZWjx","st_dist_02":"Qqk4zPTzSXaWfj8yYNDRSmr9","st_dist_03":"1Kn8wo8gjI1bK9tmxa6okJPW","st_dist_04":"SVvZuwmeoOkETZibPZYl9uzq","st_dist_05":"Tkoc8BgzhtzWq80w38RgNtgb","st_dist_06":"iSbnaR4BLa69QMvmU3SSkwvS","st_dist_07":"Fv6hwprDQuzeG82egCJvOp7o","st_dist_08":"zmahIQ0mckOULN6WChOhhRlA","st_dist_09":"ptWFqBYcJgK03HAG8we1c7TN","st_dist_10":"XEmIpNCKuW1gLn4mEe5rNgni","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"eYV77ebWhfaRppnS4hYti3SGmIkFJhxy5c09xMXBBBNr3"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1487,"st_w_id":1,"st_quantity":20,"st_dist_01":"auxRmK3hd2zgf62jCZSa4Ayp","st_dist_02":"lgudvboZdmGxDvIDFmIRYeNf","st_dist_03":"WuN8alg1K56pHKa4ZtoTHh3A","st_dist_04":"o0NGcjwidQEQoE5hb0MONefZ","st_dist_05":"Ox7gDFvsdW8w1UVn47Pa6Qfl","st_dist_06":"aQHjoKya5DnbB7ryg9Z0GIFo","st_dist_07":"xiL8TnkLCnDABJk9fP39dVXh","st_dist_08":"I4VnfpnLBAo5Kppe0DeRaWv8","st_dist_09":"NkHAoMpKtMUTuTzvMSHepaoS","st_dist_10":"e48hsBBpXRXRwCkdxuwyVBzq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"o5PRfWLsQ8Kye5PFMZXutxBJIyt0ZqNFhdm9u2nT"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1488,"st_w_id":1,"st_quantity":73,"st_dist_01":"EIfpCpGbwkyR1YRa4LT98Q2u","st_dist_02":"4osFxBAmZJerGwfrhl6LjUob","st_dist_03":"OSJA7V8jihG2VApnBeNI3BfP","st_dist_04":"OLyG5MDhuVCFh9C0V6gnXjrG","st_dist_05":"wSNzY0ttvSV4ggIAir3XKSsi","st_dist_06":"wq2ezypeqarPQr1eQDiNnQsP","st_dist_07":"vHbZ6L20zQO9l84lSYzo9QVg","st_dist_08":"F8RihNrU2YDzx1wl7BXW7wSy","st_dist_09":"XBzkjNVUM5FnLvFB6vTac0lP","st_dist_10":"R42a4zDRPiaWJvUdABb74EPD","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"XlUVdMK5vjkcJCUojzL893fysSs8KQy8eYEXzJnegycvFqpeN5"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1489,"st_w_id":1,"st_quantity":98,"st_dist_01":"UW6e3X6SX3ZUG5OE4M9Irfxv","st_dist_02":"IXpTfraoEUdSbFVjycPqTlh1","st_dist_03":"eZQi88tcQJlCrktyadgJa08c","st_dist_04":"7gbJdYzO0PcK5uJ7PXBodxpx","st_dist_05":"vfGAhTV0ydPEsTHg8bnpvlrw","st_dist_06":"ZQ8Aa0pZoJTKU0CpjQUGppEv","st_dist_07":"a6Voa1YFWlxZHMGjXPU9bMe1","st_dist_08":"vE3g7gCFhEPYg0XsCLEeqNbK","st_dist_09":"Q2e1uPr5lkVklD4AkrnJ4HfU","st_dist_10":"Gm2G3jxMkDralSJpmLXDh7M8","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"xJIx3ItQlggB6ky0WnmtKMdZv152xMU4REex1v"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1490,"st_w_id":1,"st_quantity":63,"st_dist_01":"hZzu6DnfrZvWHfKwyaLCLcjD","st_dist_02":"OFW3ueeMbbQ6UHi3Cy5J587O","st_dist_03":"eTKX3IASFdmcNnYfZSmSyBrr","st_dist_04":"vfVh85Iz9zMZbnodQSAJr0B2","st_dist_05":"iZPYseG4CqtBSekrXrOophg8","st_dist_06":"8v1MbkW8eX0Tu41EbBpSrjto","st_dist_07":"esoUCZ766w4kAoNCpGRIYKhn","st_dist_08":"5hZ1jHc952adrBMtuJ7vJYhK","st_dist_09":"zA6wvYdtzSJyYSuqLexdqoJj","st_dist_10":"jEKMufIfhqxb4NqMhEFVY1Xq","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"G1FPZe7bzmiIWXXWkedGLjdjUkTszk36yqh"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1491,"st_w_id":1,"st_quantity":33,"st_dist_01":"rwMZzNml0jP6wcmgKdbOpuEC","st_dist_02":"NZsTUFMxHCrG9J62kbAzjuQt","st_dist_03":"HKLhqhbguosVPwvl19lUpjaW","st_dist_04":"lTAWuyirZv5Z60rrVVyBYmNS","st_dist_05":"AOS1CSG09q7WzQVxLThHNbtt","st_dist_06":"TcTXnm5tTSKkDhGP0vJCmQMY","st_dist_07":"5gGqv4GlIDmwpNzp31RKDhEQ","st_dist_08":"lOYRzvWMuYSoAbZOmiilh5kg","st_dist_09":"kqSQ9RPWOY6QTKt8n6HuUIL5","st_dist_10":"Dt5btd6hDTmcNzIZGgNOGgA9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5sZdGr3i7GBWxvq6Galf8d4kT98kTtE8q6yZyOgNuE"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1492,"st_w_id":1,"st_quantity":60,"st_dist_01":"A2cw6uPeJXgrQ96kwXPlkvHs","st_dist_02":"5YvfdO8HPcGa2UXNCZLjLC6P","st_dist_03":"fpMrFsPjaBfWvX0iFQYM1Bc9","st_dist_04":"9AHvj1CaiYNk52G3Tm7lL3cS","st_dist_05":"zoEO1HB4rdienlHKgm7xjj4W","st_dist_06":"bFwideYTLTl5pWZxaWLPiCAw","st_dist_07":"y2dbXE3RiKoSS8GzzFQ2ESbN","st_dist_08":"lJmRc1IVrKntt4TjyBES1twL","st_dist_09":"MnFrDhpU6RBsdyHnoBnBBzam","st_dist_10":"FUVMTD9Z893eVrtdUl7IYdwN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0x8TQPpCIV79RSs8ymSgfqxKnyzlKP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1493,"st_w_id":1,"st_quantity":67,"st_dist_01":"4IshWqn5ssf3RpCUoA7SuuBe","st_dist_02":"Te5HYG0UdQbbAPlcIQfDSdoL","st_dist_03":"jTI4ZfuFGfOve1Iudv5rMo6k","st_dist_04":"U5kKPYMxVAVLODyoucVAeAiT","st_dist_05":"1odqoxUxTR0Ay1evzeMpLVcb","st_dist_06":"fITkpa9h7aOK0UQWIZhyKGDr","st_dist_07":"lDQL8cby1xN7803zHjlEPRDV","st_dist_08":"6yWXbHtK9PQgE7BUSHutV8NG","st_dist_09":"BFZxFbVLz9V74AlSc9dcYWQa","st_dist_10":"crK90oU3RGkrOnAZc9PBaMAb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"7j2QOd9Pl82YsQriD2FMIQjYXiOR8P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1494,"st_w_id":1,"st_quantity":49,"st_dist_01":"QgeALeOmZAhWOp9EIO6dkYue","st_dist_02":"IOc5DlQiNvTGxWthhmsuMckc","st_dist_03":"zqR7PVAobeZINmW6aFORTLIO","st_dist_04":"geZzTG6i2ttPkwK755v4ASUi","st_dist_05":"nyxLznCRVSE1obLQw4ArLWgM","st_dist_06":"gMxJEyTEP4GUZosd2taIzAKM","st_dist_07":"7FhBzufYk2Sd6ZQitkJWp2VK","st_dist_08":"FLU0sOfSlrpDApXTwUH5HVOG","st_dist_09":"ycuAfWfgixex12VTsjojmARl","st_dist_10":"NfA3WRywDMhdDjz4a54rqudh","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"9K0PUiSyGYBxsQe9NBnCuQeCQVVg8CyCUS2FoKfN2wTwA16p9"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1495,"st_w_id":1,"st_quantity":69,"st_dist_01":"x6iUL9ZFMF2uZQhSz5V9mU8j","st_dist_02":"bRWfCfhGrO5FPanZ0l3rPDym","st_dist_03":"K2HQ7jfb7onic9hoGdUgFiGD","st_dist_04":"yqDvtRotzkIOBLALHUDiszWc","st_dist_05":"utzomBxeoJPEJIJFzkRJt4nu","st_dist_06":"i0kd07a9KHlLGA0zswYeO3VX","st_dist_07":"WhEHtplqRp3xovf6WI84fXG1","st_dist_08":"1f1STV2GHdSVhUPzUvVs2NJg","st_dist_09":"NAjZdKHdjGGujlefLDly6AVA","st_dist_10":"DtSbJJYNp4DHJ2XKVdE71nyl","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UsOFvnqEzJO4JsGW0KWpCtyZ4UAGgo"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1496,"st_w_id":1,"st_quantity":45,"st_dist_01":"PPw4cLoCjwAaoBt2eCsTO9w1","st_dist_02":"T735QscY7oz6jr2Yr4Uc5DwE","st_dist_03":"LXJDnXp4p8nuYokhOH1u0vph","st_dist_04":"QcOlilFjCUPXtrHqevsWyFFA","st_dist_05":"tZeXpWhf3Ep34TOiha8hToQA","st_dist_06":"cZbxTW91ZLVI95dGF1QJ8brW","st_dist_07":"5zFy4Apdnh0ZnP9gnpxrhFDd","st_dist_08":"O9iNeATBbV3N6KN5qDuhJov7","st_dist_09":"AUW37KzUkZmA5K9t1ohJmbFQ","st_dist_10":"CWM3i4Dn2QVzwzIqmg8yeWwm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"irKIpFNtqbC10f4YprqU7jh4ZOYBIjG5BsqVqd"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1497,"st_w_id":1,"st_quantity":90,"st_dist_01":"drCjCrtxGFGnUSVmIxJWBj72","st_dist_02":"KTRAJYtnjtJ8huGPxDNzk6Jc","st_dist_03":"s1w085OFIjlPVtELyrbAbOlv","st_dist_04":"4cinJVxFT6v52o1uGWDV9OMp","st_dist_05":"v9DeZldY4MwGckS2cKPOLbbB","st_dist_06":"taqwpse79rYZxCRRtzgZLo73","st_dist_07":"8H0pSukHVne2e52lZxeIrN7h","st_dist_08":"tGZUngshKeiLA9VJtH9OMzYh","st_dist_09":"MHWes35VfTRaGxkGsAjNcuTh","st_dist_10":"g08oKcGc9SQY20ZARZ87ykRL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3hSFxp5bSXWiYQlWk01h7yLHf3nWS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1498,"st_w_id":1,"st_quantity":30,"st_dist_01":"aC24lsGh8HyaW4SCSgyF2RBT","st_dist_02":"0pnkE4PwyepREFvUv3TUnSBO","st_dist_03":"L09TcSsQDjCvL0j043QaR9SV","st_dist_04":"m3agkz7ISqc6dJNDXKU0C8ah","st_dist_05":"OUdqb3mbrvpyq5jBZndP2fLj","st_dist_06":"Xojisr9YJhRAHKg6LPiYk8jR","st_dist_07":"qhrqROSS630djqp2V2Nqjm9x","st_dist_08":"rL5WrGOZN2uaEbIKyubtGswH","st_dist_09":"HyCbwi4kTC0ySl3bFAud8aIp","st_dist_10":"7zGaXlplptLG8nGn8KkvlF56","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"5yDtFAQPQMB8R4USeafnAT3NltwohRp2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1499,"st_w_id":1,"st_quantity":87,"st_dist_01":"0wD1XBlAVhYI9tzDc57wnAbX","st_dist_02":"mpI0CC3hiRtC4pye27DK2Px1","st_dist_03":"tJATJtwYf7jmNLy4tdhhT0y3","st_dist_04":"Ga5jJICVioOTQww40hTUTGfw","st_dist_05":"I10JkJEbDEleC6RuWEvyz6EG","st_dist_06":"YlFEK4Cis851IuGOPS8RvOve","st_dist_07":"pkYXZ6YWFKVYGPkRLiiu9tgH","st_dist_08":"SwEAplTwywtlm1KblMd4cjkw","st_dist_09":"BQf0B0nCUi0AALMUSkj024XE","st_dist_10":"80JhvuF5rhvyV30dnSxbp4Lb","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"3vqX72Zkxv1HIn8Xxc05g9zFvL88peA"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1500,"st_w_id":1,"st_quantity":59,"st_dist_01":"LrTDqqryG22W5kqHYVaJBzBE","st_dist_02":"LX2aoiQM4MYmrJBT8bQBi755","st_dist_03":"hfOTAyebtysUZq0t05mlT1r7","st_dist_04":"esFRfsZDApUltPsQAPawDNrx","st_dist_05":"wJ2D5tkcwZ0nICm9pNduOSku","st_dist_06":"ZEBKZFssKtbxYkeMsEpSToNC","st_dist_07":"epiMuBpMOq8R8XwFqql5a6Ks","st_dist_08":"RnW0m5RNrJttGTAFrQFxE7oa","st_dist_09":"kEbyLi6X5oVohfknzWtDFlpC","st_dist_10":"xCuqHYhWk5DH5PO0A7EMk4qo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Sjh3tTBkPgQWt6JHV0DfGj2CbnSyI3UzwNH8xYSK8iRvY8h"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":10011,"st_w_id":1,"st_quantity":31,"st_dist_01":"7PdtuEDIx90uIzOWl4yIhCrO","st_dist_02":"mEQVDBDGRWmpnIS36CoPXITS","st_dist_03":"qnkqeBncIJZppyunbORek4AR","st_dist_04":"QTBUpGHnxDkheWkJJI81TlzJ","st_dist_05":"7rncYcJLRltFbR3AxbDsjbcO","st_dist_06":"F4ZpXYQH1fJngai75wll2ZV6","st_dist_07":"ziTG6RrRGIUr8bgLrtJZBnzK","st_dist_08":"JcoMBv5qJ2VyCUk0cuo6glD5","st_dist_09":"sPCcFWrUFCl8ms0wmy321ztw","st_dist_10":"4mZKtquZoA186nXqzWPCKOy6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PuQndcx3rkAdhhEVyH0SHwdNWqQZ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739247,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"stock","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739247,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25683224\"]","schema":"public","table":"stock","txId":4509,"lsn":25683224,"xmin":null},"op":"u","ts_ms":1665511743119,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25694128\"]","schema":"public","table":"stock","txId":4509,"lsn":25694128,"xmin":null},"op":"u","ts_ms":1665511743120,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25695168\"]","schema":"public","table":"stock","txId":4509,"lsn":25695168,"xmin":null},"op":"u","ts_ms":1665511743120,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25696200\"]","schema":"public","table":"stock","txId":4509,"lsn":25696200,"xmin":null},"op":"u","ts_ms":1665511743121,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743105,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25667312\",\"25697216\"]","schema":"public","table":"stock","txId":4509,"lsn":25697216,"xmin":null},"op":"u","ts_ms":1665511743121,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25698952\"]","schema":"public","table":"stock","txId":4510,"lsn":25698952,"xmin":null},"op":"u","ts_ms":1665511743134,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25699864\"]","schema":"public","table":"stock","txId":4510,"lsn":25699864,"xmin":null},"op":"u","ts_ms":1665511743134,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25700776\"]","schema":"public","table":"stock","txId":4510,"lsn":25700776,"xmin":null},"op":"u","ts_ms":1665511743134,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25701680\"]","schema":"public","table":"stock","txId":4510,"lsn":25701680,"xmin":null},"op":"u","ts_ms":1665511743135,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743130,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25698048\",\"25702568\"]","schema":"public","table":"stock","txId":4510,"lsn":25702568,"xmin":null},"op":"u","ts_ms":1665511743135,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25704144\"]","schema":"public","table":"stock","txId":4511,"lsn":25704144,"xmin":null},"op":"u","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25705056\"]","schema":"public","table":"stock","txId":4511,"lsn":25705056,"xmin":null},"op":"u","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25705968\"]","schema":"public","table":"stock","txId":4511,"lsn":25705968,"xmin":null},"op":"u","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25706896\"]","schema":"public","table":"stock","txId":4511,"lsn":25706896,"xmin":null},"op":"u","ts_ms":1665511743158,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743153,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25703328\",\"25707784\"]","schema":"public","table":"stock","txId":4511,"lsn":25707784,"xmin":null},"op":"u","ts_ms":1665511743159,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25709360\"]","schema":"public","table":"stock","txId":4512,"lsn":25709360,"xmin":null},"op":"u","ts_ms":1665511743179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25710360\"]","schema":"public","table":"stock","txId":4512,"lsn":25710360,"xmin":null},"op":"u","ts_ms":1665511743179,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25711272\"]","schema":"public","table":"stock","txId":4512,"lsn":25711272,"xmin":null},"op":"u","ts_ms":1665511743180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25712176\"]","schema":"public","table":"stock","txId":4512,"lsn":25712176,"xmin":null},"op":"u","ts_ms":1665511743180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743175,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25708544\",\"25713064\"]","schema":"public","table":"stock","txId":4512,"lsn":25713064,"xmin":null},"op":"u","ts_ms":1665511743180,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25714640\"]","schema":"public","table":"stock","txId":4513,"lsn":25714640,"xmin":null},"op":"u","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25715576\"]","schema":"public","table":"stock","txId":4513,"lsn":25715576,"xmin":null},"op":"u","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25716488\"]","schema":"public","table":"stock","txId":4513,"lsn":25716488,"xmin":null},"op":"u","ts_ms":1665511743204,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25717392\"]","schema":"public","table":"stock","txId":4513,"lsn":25717392,"xmin":null},"op":"u","ts_ms":1665511743205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743199,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25713824\",\"25718280\"]","schema":"public","table":"stock","txId":4513,"lsn":25718280,"xmin":null},"op":"u","ts_ms":1665511743205,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25719856\"]","schema":"public","table":"stock","txId":4514,"lsn":25719856,"xmin":null},"op":"u","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25720864\"]","schema":"public","table":"stock","txId":4514,"lsn":25720864,"xmin":null},"op":"u","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25721776\"]","schema":"public","table":"stock","txId":4514,"lsn":25721776,"xmin":null},"op":"u","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25722680\"]","schema":"public","table":"stock","txId":4514,"lsn":25722680,"xmin":null},"op":"u","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743223,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25719040\",\"25723592\"]","schema":"public","table":"stock","txId":4514,"lsn":25723592,"xmin":null},"op":"u","ts_ms":1665511743227,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25725168\"]","schema":"public","table":"stock","txId":4515,"lsn":25725168,"xmin":null},"op":"u","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25726080\"]","schema":"public","table":"stock","txId":4515,"lsn":25726080,"xmin":null},"op":"u","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25726992\"]","schema":"public","table":"stock","txId":4515,"lsn":25726992,"xmin":null},"op":"u","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25727896\"]","schema":"public","table":"stock","txId":4515,"lsn":25727896,"xmin":null},"op":"u","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743247,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25724352\",\"25728784\"]","schema":"public","table":"stock","txId":4515,"lsn":25728784,"xmin":null},"op":"u","ts_ms":1665511743251,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25730360\"]","schema":"public","table":"stock","txId":4516,"lsn":25730360,"xmin":null},"op":"u","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25731392\"]","schema":"public","table":"stock","txId":4516,"lsn":25731392,"xmin":null},"op":"u","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25732304\"]","schema":"public","table":"stock","txId":4516,"lsn":25732304,"xmin":null},"op":"u","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25733208\"]","schema":"public","table":"stock","txId":4516,"lsn":25733208,"xmin":null},"op":"u","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743327,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25729544\",\"25734096\"]","schema":"public","table":"stock","txId":4516,"lsn":25734096,"xmin":null},"op":"u","ts_ms":1665511743331,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25735672\"]","schema":"public","table":"stock","txId":4517,"lsn":25735672,"xmin":null},"op":"u","ts_ms":1665511743358,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25736584\"]","schema":"public","table":"stock","txId":4517,"lsn":25736584,"xmin":null},"op":"u","ts_ms":1665511743358,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25737496\"]","schema":"public","table":"stock","txId":4517,"lsn":25737496,"xmin":null},"op":"u","ts_ms":1665511743359,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25738400\"]","schema":"public","table":"stock","txId":4517,"lsn":25738400,"xmin":null},"op":"u","ts_ms":1665511743359,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743353,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25734856\",\"25739312\"]","schema":"public","table":"stock","txId":4517,"lsn":25739312,"xmin":null},"op":"u","ts_ms":1665511743359,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":47,"st_dist_01":"YrByUiNwCTQNh4qxf765paeJ","st_dist_02":"hSiR0KnowDKSPFDaoYDA6B4I","st_dist_03":"u1PeeTQp5DFQ9fF45SSXisog","st_dist_04":"3zwIBVRYulhJ9c4sRrrOFkOq","st_dist_05":"dnQfwuP7u6LGpVN1deJE7ffM","st_dist_06":"9u4mLDTsyRQVeaFYO01RnIX2","st_dist_07":"TqnNeAVVrxyHmxNawsjOtvEu","st_dist_08":"GOMnjuN8QH5wyT3Uun6eAq1j","st_dist_09":"SQebD61lib52Sy1u330YYqNI","st_dist_10":"1CDarxAlKDxQtHiNRonb3HCe","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"prwA0nCQJi2FQfj2sAegCD9aBautmkku14OjROG7FCi3C"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25740888\"]","schema":"public","table":"stock","txId":4518,"lsn":25740888,"xmin":null},"op":"u","ts_ms":1665511743381,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":59,"st_dist_01":"e9XozuwT3DNZV4hRaCGWoRjv","st_dist_02":"CGbiPwECriqUnhMufi0gPAS2","st_dist_03":"NzuPcaz8gZscR4ymXasWrWID","st_dist_04":"DsdLZ1YFA7FAQBchenRb7pnE","st_dist_05":"RML8AntdQgBNpLHi6NFpfK2j","st_dist_06":"fiRJd6cQywJkQYHGyBXSipiN","st_dist_07":"kjpx7Z1TmneMlrtt3yyHVXND","st_dist_08":"8QBHb3C0Es7BP5gTrs0dq1zN","st_dist_09":"acJi4tV7gsCfvZJ6qPiWfJGa","st_dist_10":"17KRYD9BjfTiWXADH9tHkczo","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"dHpPJK03lHULG3LAVtlYXJ8aluF4dOdgnMr2fkZLoddxF"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25741896\"]","schema":"public","table":"stock","txId":4518,"lsn":25741896,"xmin":null},"op":"u","ts_ms":1665511743382,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":95,"st_dist_01":"7SIXxdig2RUmuLFd0QfIppiG","st_dist_02":"9mRI4dAnfnvml5K8BAXZyyS7","st_dist_03":"sF9nN4j8lJrX0xl8gTU6gKZr","st_dist_04":"EEKGZ9OrCslsg94JDZZSmHY7","st_dist_05":"dmH9KBV3ecEAYOGQqk4pLpHy","st_dist_06":"z0qNxoXdN5Y0CUpNC31z5H9w","st_dist_07":"o0sKhCVVzVkdTJyjcIrUzoFu","st_dist_08":"BNV2KQK5dbnlg0DZ2tDut90W","st_dist_09":"1TGLIUA8pblcjqNENyB9vPuF","st_dist_10":"WYlz4bFCSCDqPZ0QQHtNxMX9","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"wfkW5OKWRne2uGPNDt4P2YR8MoAgXue6wmfAbwcu"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25742808\"]","schema":"public","table":"stock","txId":4518,"lsn":25742808,"xmin":null},"op":"u","ts_ms":1665511743382,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":93,"st_dist_01":"r3uaTECAqVVhOqWQ0VjFYoHP","st_dist_02":"ZQZRn5goNg3Swf5fyB6g4pTc","st_dist_03":"mKaH5I3hPy9uSjGueT7DIooo","st_dist_04":"KluSpIjT1DtG7yPY1E9ALPqx","st_dist_05":"WXOCTe4UAmzBR5lOcSWabrYB","st_dist_06":"LRpP9zvNLOkbpu06eWeiPY60","st_dist_07":"xHUPjRt1CPgPJtCMDCGnFEmn","st_dist_08":"zaeZMUfMMm8omH8IUyHZHV5o","st_dist_09":"FaZac3hhPC4kxLuBwIxibG8E","st_dist_10":"GhkY2HarmL0NXpZwNr2FHnUk","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"W9MW0JDw9ChIspxaOGHxLfHQ4RAKIDoK"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25743712\"]","schema":"public","table":"stock","txId":4518,"lsn":25743712,"xmin":null},"op":"u","ts_ms":1665511743382,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":27,"st_dist_01":"XtXFAi9wd2q1EjmzmjRUgz0o","st_dist_02":"TGNxEYtbQspqYFMyIcR5NPgK","st_dist_03":"L1HVnfPfcUvyc0WQaS2d7pAx","st_dist_04":"iDET7nR1EExCgtix3RUyt4Yc","st_dist_05":"XmBuUfcjlTfqPrRTxgbxIORz","st_dist_06":"DRsTsUo2EZ44ABG244hYsQiW","st_dist_07":"3klWhgfP1fuSaUpGPjINk6Hc","st_dist_08":"3WN2LLcIoUxj1C32K5Nt2iOM","st_dist_09":"QQ499vQUwOfS0TE6XHX03tgn","st_dist_10":"rTD8OBVEgBiDEofJy0tHX14m","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"UEtXS5SMCbWmX4us1rURC90208EfoPE7MRCyNmh4t"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743377,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25740072\",\"25744600\"]","schema":"public","table":"stock","txId":4518,"lsn":25744600,"xmin":null},"op":"u","ts_ms":1665511743382,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25754304\"]","schema":"public","table":"stock","txId":4519,"lsn":25754304,"xmin":null},"op":"u","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25755328\"]","schema":"public","table":"stock","txId":4519,"lsn":25755328,"xmin":null},"op":"u","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25756400\"]","schema":"public","table":"stock","txId":4519,"lsn":25756400,"xmin":null},"op":"u","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25757416\"]","schema":"public","table":"stock","txId":4519,"lsn":25757416,"xmin":null},"op":"u","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743401,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25745360\",\"25758432\"]","schema":"public","table":"stock","txId":4519,"lsn":25758432,"xmin":null},"op":"u","ts_ms":1665511743404,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25760144\"]","schema":"public","table":"stock","txId":4520,"lsn":25760144,"xmin":null},"op":"u","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25761128\"]","schema":"public","table":"stock","txId":4520,"lsn":25761128,"xmin":null},"op":"u","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25762048\"]","schema":"public","table":"stock","txId":4520,"lsn":25762048,"xmin":null},"op":"u","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25762936\"]","schema":"public","table":"stock","txId":4520,"lsn":25762936,"xmin":null},"op":"u","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743423,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25759264\",\"25763824\"]","schema":"public","table":"stock","txId":4520,"lsn":25763824,"xmin":null},"op":"u","ts_ms":1665511743428,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25765424\"]","schema":"public","table":"stock","txId":4521,"lsn":25765424,"xmin":null},"op":"u","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25766400\"]","schema":"public","table":"stock","txId":4521,"lsn":25766400,"xmin":null},"op":"u","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25767320\"]","schema":"public","table":"stock","txId":4521,"lsn":25767320,"xmin":null},"op":"u","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25768208\"]","schema":"public","table":"stock","txId":4521,"lsn":25768208,"xmin":null},"op":"u","ts_ms":1665511743450,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":2,"st_remote_cnt":2,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743446,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25764608\",\"25769096\"]","schema":"public","table":"stock","txId":4521,"lsn":25769096,"xmin":null},"op":"u","ts_ms":1665511743451,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25770672\"]","schema":"public","table":"stock","txId":4522,"lsn":25770672,"xmin":null},"op":"u","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25771656\"]","schema":"public","table":"stock","txId":4522,"lsn":25771656,"xmin":null},"op":"u","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25772600\"]","schema":"public","table":"stock","txId":4522,"lsn":25772600,"xmin":null},"op":"u","ts_ms":1665511743471,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25773488\"]","schema":"public","table":"stock","txId":4522,"lsn":25773488,"xmin":null},"op":"u","ts_ms":1665511743472,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":3,"st_remote_cnt":3,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743468,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25769856\",\"25774376\"]","schema":"public","table":"stock","txId":4522,"lsn":25774376,"xmin":null},"op":"u","ts_ms":1665511743472,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25775952\"]","schema":"public","table":"stock","txId":4523,"lsn":25775952,"xmin":null},"op":"u","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25776936\"]","schema":"public","table":"stock","txId":4523,"lsn":25776936,"xmin":null},"op":"u","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25777856\"]","schema":"public","table":"stock","txId":4523,"lsn":25777856,"xmin":null},"op":"u","ts_ms":1665511743495,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25778744\"]","schema":"public","table":"stock","txId":4523,"lsn":25778744,"xmin":null},"op":"u","ts_ms":1665511743496,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":4,"st_remote_cnt":4,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743491,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25775136\",\"25779632\"]","schema":"public","table":"stock","txId":4523,"lsn":25779632,"xmin":null},"op":"u","ts_ms":1665511743496,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25781232\"]","schema":"public","table":"stock","txId":4524,"lsn":25781232,"xmin":null},"op":"u","ts_ms":1665511743515,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25782216\"]","schema":"public","table":"stock","txId":4524,"lsn":25782216,"xmin":null},"op":"u","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25783136\"]","schema":"public","table":"stock","txId":4524,"lsn":25783136,"xmin":null},"op":"u","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25784024\"]","schema":"public","table":"stock","txId":4524,"lsn":25784024,"xmin":null},"op":"u","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":5,"st_remote_cnt":5,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743512,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25780416\",\"25784912\"]","schema":"public","table":"stock","txId":4524,"lsn":25784912,"xmin":null},"op":"u","ts_ms":1665511743516,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25786488\"]","schema":"public","table":"stock","txId":4525,"lsn":25786488,"xmin":null},"op":"u","ts_ms":1665511743534,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25787472\"]","schema":"public","table":"stock","txId":4525,"lsn":25787472,"xmin":null},"op":"u","ts_ms":1665511743535,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25788392\"]","schema":"public","table":"stock","txId":4525,"lsn":25788392,"xmin":null},"op":"u","ts_ms":1665511743535,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25789304\"]","schema":"public","table":"stock","txId":4525,"lsn":25789304,"xmin":null},"op":"u","ts_ms":1665511743535,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":6,"st_remote_cnt":6,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743531,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25785672\",\"25790192\"]","schema":"public","table":"stock","txId":4525,"lsn":25790192,"xmin":null},"op":"u","ts_ms":1665511743535,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25791768\"]","schema":"public","table":"stock","txId":4526,"lsn":25791768,"xmin":null},"op":"u","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25792752\"]","schema":"public","table":"stock","txId":4526,"lsn":25792752,"xmin":null},"op":"u","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25793672\"]","schema":"public","table":"stock","txId":4526,"lsn":25793672,"xmin":null},"op":"u","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25794560\"]","schema":"public","table":"stock","txId":4526,"lsn":25794560,"xmin":null},"op":"u","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":7,"st_remote_cnt":7,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743550,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25790952\",\"25795448\"]","schema":"public","table":"stock","txId":4526,"lsn":25795448,"xmin":null},"op":"u","ts_ms":1665511743553,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25797048\"]","schema":"public","table":"stock","txId":4527,"lsn":25797048,"xmin":null},"op":"u","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25798032\"]","schema":"public","table":"stock","txId":4527,"lsn":25798032,"xmin":null},"op":"u","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25798952\"]","schema":"public","table":"stock","txId":4527,"lsn":25798952,"xmin":null},"op":"u","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25799840\"]","schema":"public","table":"stock","txId":4527,"lsn":25799840,"xmin":null},"op":"u","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":8,"st_remote_cnt":8,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743567,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25796208\",\"25800728\"]","schema":"public","table":"stock","txId":4527,"lsn":25800728,"xmin":null},"op":"u","ts_ms":1665511743571,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":29,"st_dist_01":"rM2xVi1yborRGwM3mjWkXOl5","st_dist_02":"FpUY1GK6eLYSTHIDVez1nUxF","st_dist_03":"DVY3qhSRCbwPOxzwOuKHZzCT","st_dist_04":"wQNOvwXtUdU4S9B3VHqsLr9e","st_dist_05":"QPhJt9dUOh9c4M1MyZGv9Rfu","st_dist_06":"ZoGw8eXu6BnM9zaOzLtP1lyI","st_dist_07":"5ktYD8r6k87vn47P8qQetX1l","st_dist_08":"o9LMW7kXaW9WjocvNrYUiLkI","st_dist_09":"a5juNFkABrHe47RXGChaQ9cg","st_dist_10":"PHMixeZ6E5kuPjnDgOtsCyCw","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"Qr7HKT42YSpiR3tDtXOPs0dk1vKoSwj07D"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25802304\"]","schema":"public","table":"stock","txId":4528,"lsn":25802304,"xmin":null},"op":"u","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":88,"st_dist_01":"oppD4Q6SFHePqENAOc3H1YJe","st_dist_02":"02j0XPbpm5HRFBgadJ2bgHAB","st_dist_03":"HcvIcHrl0AmMRCsGOXzbaKF2","st_dist_04":"jtbHEjZAOj903OtiuNZytsQT","st_dist_05":"Obgy54lmW3QcK6HoN7MJgINU","st_dist_06":"l1ql9fh600NxCkWHmrhzAgd2","st_dist_07":"R0LFzwZKRTADcUpiNb91E1MZ","st_dist_08":"gK5KjGgOM2Rrj2hgG8qBCE1L","st_dist_09":"Q0cImRlyJ3ZZoTo68c0M9uwK","st_dist_10":"DzpbLiow0gk32HGemgr2QSxr","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"66clGfnbXW55gMKdkvoYgGePZM2GsFjuoZdHj01LquCTSMVs"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25803288\"]","schema":"public","table":"stock","txId":4528,"lsn":25803288,"xmin":null},"op":"u","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":89,"st_dist_01":"cDEmUZnoX5nJVLi9nlUh0p32","st_dist_02":"VQqpPnvxwqwEgb8HbXkqJ1fc","st_dist_03":"LfcyCnSlo43LGDuKOZChGSvg","st_dist_04":"Kb6nvxGCYBEpkl7V6nD3rC7k","st_dist_05":"vjgWV1KRGF7KmX9Tj5RnkX59","st_dist_06":"lxLQDLgjtmtbohIfYCOVFR6E","st_dist_07":"UPOq77tULtXfNtvNmW84Wq7H","st_dist_08":"mLr8SZxTtpQQA2YvsqLlNm0y","st_dist_09":"NZoT5ekbsLo70B8Nh75KOORT","st_dist_10":"CwPn7DD6LS6nNfwTN20XOTvm","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"qxmoriginal7HfyXkXs5m4mUM9VqtXJ"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25804208\"]","schema":"public","table":"stock","txId":4528,"lsn":25804208,"xmin":null},"op":"u","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":21,"st_dist_01":"D8UgXtu4PQH4YR7S76y2akWs","st_dist_02":"pureWczDXLiX205i6ipmP47x","st_dist_03":"XII74X0giGfKosC9dD82Qwnb","st_dist_04":"OOTfl2lN8r80GVIQAPQuPfPN","st_dist_05":"56dJcPKIAflVl9yCPMKdsMC2","st_dist_06":"icqGKJAYt8pta18Gl5JbJXtw","st_dist_07":"2HIqBO4xBPRbmazWKCmtySlr","st_dist_08":"RtkEdm1t6vP53VnqVimIWrO7","st_dist_09":"NPAnBKanE413IK0FHRWWrJaJ","st_dist_10":"eSGzvwuVpbPojBrTJFIJNpfo","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"HWebrIJJ3rv6NseUb0ujVMqExTpaYJS"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25805120\"]","schema":"public","table":"stock","txId":4528,"lsn":25805120,"xmin":null},"op":"u","ts_ms":1665511743594,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":9,"st_remote_cnt":9,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":72,"st_dist_01":"rXZcWELSDpwAdhXBZl7obTMm","st_dist_02":"klH8VQQo8TLHdJnIXAyNlWVC","st_dist_03":"jzxcyzx7u4gXkj9ldrPbmMQP","st_dist_04":"SDlpTSYrftFuJhOAzUuYHW5h","st_dist_05":"BRWbA2sCvdlfpZlCcWDC8gig","st_dist_06":"b3wYF38mv5dXz5lXcO4ffPMa","st_dist_07":"3gvSiM1VnUdFoOXqvJUvzlRd","st_dist_08":"2pWetn0OfFsqxbAoSnCK3L1i","st_dist_09":"3CBAM718ylCVVg8kKnAxLkhx","st_dist_10":"vWdz0TDnc0anWRFWJT95JKBu","st_ytd":0,"st_order_cnt":10,"st_remote_cnt":10,"st_data":"duonZG54PGx2ONnmGsAWsbH9ovnWeqztVqyI0pXEY"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743590,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25801488\",\"25806008\"]","schema":"public","table":"stock","txId":4528,"lsn":25806008,"xmin":null},"op":"u","ts_ms":1665511743594,"transaction":null}} diff --git a/scripts/source/test_data/tpcc_district.1 b/scripts/source/test_data/tpcc_district.1 deleted file mode 100644 index fc6816c02bbde..0000000000000 --- a/scripts/source/test_data/tpcc_district.1 +++ /dev/null @@ -1,12 +0,0 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":1,"d_w_id":1,"d_name":"PgLwPg","d_street_1":"R6i6Bwi0L6wikNB6wPi","d_street_2":"0NRiwmRgwNyNL2R4m","d_city":"PP2w y2NNLy","d_state":"PB","d_zip":"526711111","d_tax":0.0712,"d_ytd":65355.6,"d_next_o_id":3021},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3011},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":3,"d_w_id":1,"d_name":" NmBg6NP","d_street_1":"PkL6RmN yNiPiB0","d_street_2":"k2B60R4i44y0","d_city":"wN4mL BPkN66yw Lig","d_state":"44","d_zip":"655311111","d_tax":0.1298,"d_ytd":52280.5,"d_next_o_id":3017},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":4,"d_w_id":1,"d_name":"0gByykiLy","d_street_1":"6BLmwwNRBLiR0ig0","d_street_2":"24 wiN04mmNLwmLPRRy","d_city":"yNNBgPw RyN2w240BP","d_state":" w","d_zip":"654011111","d_tax":7.0E-4,"d_ytd":60137.6,"d_next_o_id":3013},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":5,"d_w_id":1,"d_name":"6Nw 4gi","d_street_1":"mNPyggLPR2gi4","d_street_2":"y ig RRLPim","d_city":"4m LR4iP4 BkRw6 P6","d_state":"L2","d_zip":"292511111","d_tax":0.0228,"d_ytd":66315.1,"d_next_o_id":3008},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":6,"d_w_id":1,"d_name":"N4RNiNgPLL","d_street_1":"0LNmw4LBPP","d_street_2":"k0i4mg62w k6wwLwBN6B","d_city":"i04ywLw4LPBm k6PmyR","d_state":"gL","d_zip":"158511111","d_tax":0.1015,"d_ytd":58980.7,"d_next_o_id":3011},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":7,"d_w_id":1,"d_name":"BRBgNigP4R","d_street_1":"gB2Bm0m0gP0wgL2PN","d_street_2":"yiBwgig 0Li6Ngy0N4","d_city":"PP4N42wBPBLwNLPL6yL","d_state":"ii","d_zip":"737511111","d_tax":0.0689,"d_ytd":63425.4,"d_next_o_id":3014},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":8,"d_w_id":1,"d_name":"kR4RmggL","d_street_1":"0ggRi0iB 0","d_street_2":" gg2BygLNR0","d_city":"N2Pi2i6PPBN4ik","d_state":"Ri","d_zip":"340311111","d_tax":0.1599,"d_ytd":60821.2,"d_next_o_id":3016},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":9,"d_w_id":1,"d_name":"PRLii6wwLg","d_street_1":"mNNB2Nw2RLBL6yiN g","d_street_2":"0mNL0yLR wRimB6P2B","d_city":"yyRgk00NkB222PNgwgN","d_state":"w6","d_zip":"323911111","d_tax":0.0292,"d_ytd":38974.5,"d_next_o_id":3018},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":null,"after":{"d_id":10,"d_w_id":1,"d_name":"0Rggm0","d_street_1":"iNkg4R0g6RB0N","d_street_2":"0iw64R2mNgyL66PN2","d_city":"B60my 0k66BB02BRgm","d_state":"mP","d_zip":"923711111","d_tax":0.121,"d_ytd":54802.7,"d_next_o_id":3013},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081172,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"district","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081172,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3011},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3012},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24468088\"]","schema":"public","table":"district","txId":1330,"lsn":24468088,"xmin":null},"op":"u","ts_ms":1664141081528,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"d_id"},{"type":"int32","optional":false,"field":"d_w_id"},{"type":"string","optional":true,"field":"d_name"},{"type":"string","optional":true,"field":"d_street_1"},{"type":"string","optional":true,"field":"d_street_2"},{"type":"string","optional":true,"field":"d_city"},{"type":"string","optional":true,"field":"d_state"},{"type":"string","optional":true,"field":"d_zip"},{"type":"float","optional":true,"field":"d_tax"},{"type":"float","optional":true,"field":"d_ytd"},{"type":"int32","optional":true,"field":"d_next_o_id"}],"optional":true,"name":"postgres.public.district.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.district.Envelope"},"payload":{"before":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3012},"after":{"d_id":2,"d_w_id":1,"d_name":"wgRmBLP 6","d_street_1":"Li42g0L0PR","d_street_2":"y wmwNgk2","d_city":"iig26BL 4gNLg0","d_state":"k0","d_zip":"924011111","d_tax":0.0729,"d_ytd":64269.1,"d_next_o_id":3013},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24492776\"]","schema":"public","table":"district","txId":1331,"lsn":24492776,"xmin":null},"op":"u","ts_ms":1664141081534,"transaction":null}} diff --git a/scripts/source/test_data/tpcc_item.1 b/scripts/source/test_data/tpcc_item.1 deleted file mode 100644 index b2c3caf6481ac..0000000000000 --- a/scripts/source/test_data/tpcc_item.1 +++ /dev/null @@ -1,100 +0,0 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":1,"i_im_id":1,"i_name":"B44imm6Bi4Rw NN","i_price":22.67,"i_data":"2ORIGINALwNBRm0wkmN6y6PwPPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081174,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":2,"i_im_id":5298,"i_name":"BNN0RwL2N6 iikRg6Py2B","i_price":59.31,"i_data":"wR4 i2 gyPkNB6Py06i Lw0L2L2R6BB wm2B 4kmL2Rgm4N2N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":3,"i_im_id":3283,"i_name":"N2m2mkRi00ik06gwmggw","i_price":98.28,"i_data":"L w miwLB myy RPmw0BPymL6RiP4k2BN006RRLkRPiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":4,"i_im_id":2750,"i_name":"mgRyy LkB04 g64B6","i_price":6.99,"i_data":"R PiRikyNPLRm2mmgi 0NPkL06wBNkgP gPP Ny6y6RyRRg4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":5,"i_im_id":2771,"i_name":"6Ni4P2wgy40wmy6g Lm4yw","i_price":77.25,"i_data":"2k0PBiL0RPi02LBykkRg4PLiBBkRLwk4i0y 6k406gPg6k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":6,"i_im_id":3511,"i_name":"w6BkPi0B iPR6g2m4mi","i_price":27.66,"i_data":"iRg6NmyP640026i4N02wmkBk y60PRBi ig2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":7,"i_im_id":4985,"i_name":"00R4wRkR0LL04R4P060L6B06","i_price":16.81,"i_data":"006w kyyiBPRBmPyB Rk6miBRL06R2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":8,"i_im_id":9379,"i_name":"yk6Rw6P mm2kLk62","i_price":15.88,"i_data":"LRgB6ygLm6wL620L4i6 g6LPP2P2LiN0PkPwBi 46g2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":9,"i_im_id":9834,"i_name":"0B4R wgm Rw0 BmNy4","i_price":46.94,"i_data":"LyyRBw iBy6 0mLB0kBmkRLBwmNw mB iLNk64g yygwmw402"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":10,"i_im_id":2033,"i_name":"Ngm 4 w0i0P4 P","i_price":94.81,"i_data":"mii4BR2Lw64mN4PB6g6yk6RLRi006gN2PBmL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":11,"i_im_id":4554,"i_name":"BkL66L20kg iBB0LN","i_price":22.31,"i_data":"i26y2L0RRm4wPNggPiy20i46R0L 0NPkymmBi0gmiw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":12,"i_im_id":6328,"i_name":"w24kmP RNBLmw6Bmki","i_price":95.49,"i_data":"0RNPiw0i4NR4L0RiPyLNiPg02Bgy2R462N6B04y662N y2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":13,"i_im_id":8008,"i_name":"mgR2w64ByP0ww 6PgiNPP","i_price":7.45,"i_data":"0R i06Lmyy4Pw wPP6kBiRNy2L6 2gLLP46yiRmNLB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":14,"i_im_id":9894,"i_name":"gg2N66iw m66N6R0","i_price":44.53,"i_data":"60NBg 0wggy06N 40660P0yORIGINALLR6L 0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081175,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081175,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":15,"i_im_id":7274,"i_name":"Rk0y2 k0ww4wPLw4y","i_price":83.81,"i_data":"gm6NkB4kLNPPgyP6ig4mw2yiByR6w kRBy RNPBP6wL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081176,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":16,"i_im_id":9476,"i_name":"gP yk46LgByP2wiw N","i_price":78.61,"i_data":"y2 Liw202Bk2iyR64 kBigk02gi LwykN4m4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081176,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":17,"i_im_id":6011,"i_name":"Ry6RkRiRNy6mPy0","i_price":26.46,"i_data":"wBgRNiw NyRggLB6BiNBgB6giN6gLB0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081176,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":18,"i_im_id":6335,"i_name":" 4iiNR mPyi 4","i_price":70.29,"i_data":" k0gmiLRwPiNm6L0m4BPBRmNkB46"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081176,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081177,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":19,"i_im_id":1617,"i_name":"iR0LgPyBLmBygBLyP0i","i_price":32.28,"i_data":"6m0mPRki6gN40BPwRRyP4ymR0iRyR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081177,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":20,"i_im_id":3931,"i_name":"ykk42LBLm6i02gkwyR","i_price":37.6,"i_data":"gwB0y66gkwPkP4R6g6By44mByyi 46wN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081177,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":21,"i_im_id":3216,"i_name":"BNyNPR62my6P2 4LmBm","i_price":98.67,"i_data":"Nky6y6 kRiRRiyN0424P46LRk2Bw4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081177,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":22,"i_im_id":6430,"i_name":"0kRw2kPLRky42P2kLLiw","i_price":84.56,"i_data":"0Nmy4P iimRL42PBg0iyPByw y2mg R 260gBNkPPiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081177,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":23,"i_im_id":6957,"i_name":"LNmwmiP 4y0B0kRw6","i_price":8.91,"i_data":"L02g4NyBLim44iwkgN004024Ry4i0P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":24,"i_im_id":669,"i_name":"Lmk66N4Pm N LB6N6LL","i_price":66.25,"i_data":"imi2NgLR6kwyLymB4kggg0k2wk06ig64iNR4k NNLi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":25,"i_im_id":2207,"i_name":"2RmPRyi2my0mNm","i_price":30.4,"i_data":"yNPP2gwNm4 ggkPLRmR6LkwL yP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":26,"i_im_id":6957,"i_name":"gwLNwmP0BkNg2wLL4ky0","i_price":54.7,"i_data":"Rm4iiygw6PwR6y66mLk0 iR6Rw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":27,"i_im_id":5363,"i_name":"N6ikLkkgi2 gwL","i_price":35.78,"i_data":"mBk6NRNmLBR0P6LBiBL46w4kiymgBkg4Ni2NP0Rmk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":28,"i_im_id":8131,"i_name":"igm wLm0wmw6B2BwPi26k4i","i_price":66.89,"i_data":"RRg2 m4LkL2y2RL4y46RBNimwP62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":29,"i_im_id":826,"i_name":"4kkP6LNNPk0i22L2gmi2B","i_price":8.95,"i_data":"N4Lwk22ik0P BRmL yPg BiykRim00wm06ww4L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":30,"i_im_id":7568,"i_name":"gN0my4m6wyRm2R","i_price":65.61,"i_data":"LPPkg ii6ywmB4yLRwi L2BLyi4iLw2PgyyLwBLLL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":31,"i_im_id":9492,"i_name":"i6gwLLyi02PLR PB0y0","i_price":72.47,"i_data":"4y00LPk0m6kRNyPmP64k mBwRNkyk640PN2kPg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":32,"i_im_id":4460,"i_name":"00R R24yPmkkgL6L 6m4","i_price":26.24,"i_data":"L i0LBg6wPikBwyikPBPwRkyNLL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":33,"i_im_id":4239,"i_name":"06wy wk22RNywgg0R","i_price":83.83,"i_data":"4gP46i2wi0gRLmNBLNwg42gPNg02L40Bk 4gPi6w62m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":34,"i_im_id":4724,"i_name":"2P4 Nykmi N6RkgR0","i_price":67.21,"i_data":"Bw4Nw2iRN 6 4gmNgNR6PLgwPiLB04Bwm4yL2m4iL N6064"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":35,"i_im_id":6647,"i_name":"P0y4wgk4y4BLPPBkim","i_price":94.66,"i_data":" NwiNywkPRkimwiiy6 iyiLLRLPBim"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":36,"i_im_id":7265,"i_name":"2Nkkg46B0B0i 4N L","i_price":16.17,"i_data":"BRi6L yRwP Ng40ymyLyi66P B4RBPii0kB6Py wPRy0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":37,"i_im_id":7116,"i_name":"NmkkBNBm6ygRm20B R","i_price":86.26,"i_data":"wNm66gLmBNLLgPPk2PPNL00BmPg gPP6Lym4L4Pkg6Piy yLkN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":38,"i_im_id":4036,"i_name":"PR464g0k0iL kPgN0k6g0 g0","i_price":99.77,"i_data":"k2y44LiL 0044 B604wmyLByNwi yR L By0ww06g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":39,"i_im_id":411,"i_name":" 0BNL202wNmg4BPyi","i_price":56.59,"i_data":"0imPPLLiyw024wwiw4BB2m64P66giBRk66ykBBBimNPwRB2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":40,"i_im_id":2217,"i_name":"2PmRPPLm yLi6wPm i","i_price":76.47,"i_data":"kNy6RL2iwPRRgy0mBNR0LkNL06466RNkmBkNwBk2 Bg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":41,"i_im_id":5194,"i_name":"4Bwkyyky220NPmR2Bw0","i_price":53.61,"i_data":"P2yBygiPwNy0LLLw PPL0B0wymBNB0g6BPRg4PBPBLL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":42,"i_im_id":5023,"i_name":"mRyPN R0gL0gg2PN4iPm0B","i_price":25.27,"i_data":"04BR62kimLN RyN04NLL0Rii00Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":43,"i_im_id":4867,"i_name":" m4NBwRkP26wBy0PBB 2","i_price":53.89,"i_data":"wBimNmRg0kmPRP y66P0yPL6m2 Rw4P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":44,"i_im_id":7831,"i_name":"Bg6Lw4 NLmi imPmkwwyP6PB","i_price":90.06,"i_data":"NBNB R6ygR00P40 iLk0kR4im60ikNL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081178,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":45,"i_im_id":1230,"i_name":"Rym4BkLg00kPg4NNBm","i_price":10.88,"i_data":"By6LiiPkRgRk 0mPmNykimiykRkmLLN4mwR m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081178,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":46,"i_im_id":1145,"i_name":"gB6kg4NP202iiRgw62Rg0m66","i_price":16.79,"i_data":"iikL y2k44yw2i6gg L6iLm 04m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":47,"i_im_id":3084,"i_name":"R4iLmygg64Lgwi","i_price":90.22,"i_data":"6 P0yi yBR0gBRNwkw2g2002P 2B g2k4wkk 6 gRiiLP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":48,"i_im_id":8119,"i_name":"4y 664262R2LLPw606","i_price":88.2,"i_data":"NP4BB PiLwi2BRy40Nk6kw2yRPPB6 6kBm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":49,"i_im_id":899,"i_name":"LyBw2yy2yNLwNww","i_price":56.7,"i_data":"i R 6RBgwkLkg Bk6y64gw2 6P6PB0ikBwLLgwy6B0 062"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":50,"i_im_id":769,"i_name":"Py2R20P6i ik0yw","i_price":39.7,"i_data":"R20wBiwBNw6k0 22P4Bg4Lk0iPBgki6Ly60w4N R R420Lg642"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":51,"i_im_id":4997,"i_name":"gm0B0gLg gygmi PwBNLy6","i_price":97.28,"i_data":"kiPmwByN 46 2kkg4kwBmgiiBimRRBiLN ky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":52,"i_im_id":5857,"i_name":"mLyRgBP246Lw 2Ng L","i_price":15.73,"i_data":"Ngy 0P0kwBRiLk4LB iiRBi6m 6Bki4y06gL iLRmP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":53,"i_im_id":6465,"i_name":"4yiBgmyw 6NRP4i2 406P","i_price":69.67,"i_data":"LBPyi 66wykB2wi 0R mORIGINALN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":54,"i_im_id":3820,"i_name":"g66NiNR44mRi0LiRgLi","i_price":13.31,"i_data":"Bw4LLg2 m4mB6L6k 42 LP0gmw6mLy6wywRwykgig"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":55,"i_im_id":4156,"i_name":"Pmm0R yyPy6mR4ky2","i_price":47.04,"i_data":"g02BL620yR06y4Bk6PwR0R0 kwNkN02Liyk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":56,"i_im_id":1812,"i_name":"ggLi0k myPLwPLgPR","i_price":63.16,"i_data":"N6N24g4kyLRiN26 w2BN4mP4wP6 ggw2y6BRiiBNkPNPy60Rk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":57,"i_im_id":6586,"i_name":"Ry2 PPPi224444B4mi04NgR2","i_price":28.6,"i_data":"iyPiPN0wRk0g42kiR4yyiL2wyLPk 06ygi6PiyN4yi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":58,"i_im_id":8692,"i_name":"2L0w22wy k 2626BB","i_price":42.18,"i_data":"m6NN4wywgk 6wwPwwkgNg04imNLkR0L0 0yN4mRwB4Pm6y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":59,"i_im_id":2470,"i_name":"0gNLB6220yLLwRkB46LNRmg","i_price":84.03,"i_data":"B4gL4PkkmggwORIGINALgNyRRm6ykwmggwBNmmP46k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":60,"i_im_id":8551,"i_name":"PBBkyLwL4RLNNkLw2k","i_price":28.67,"i_data":"g4LiwNLP6PgmL040g6R0LmwPN6wwLN0RLyB y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":61,"i_im_id":8958,"i_name":"Li2RBiyBR 6RBk2wm0","i_price":94.77,"i_data":"26LR4LPNP2mmLBBy NN4gw2iiywR2 wP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":62,"i_im_id":504,"i_name":" iRL 02 BRi NkB kLmBy4yk","i_price":50.68,"i_data":"kwymR2iiBP B4RLmm2i40ikgyP00mkiP4w6iyLL4NP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":63,"i_im_id":1235,"i_name":"0NP2 ww6BR4mmiwP46P4L","i_price":19.61,"i_data":"ik24kRPgPy2k0 yRL wPmk42i4L Ly2k4Bi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":64,"i_im_id":2237,"i_name":"2y244Pg w6LiRPPBg 6kg","i_price":70.27,"i_data":" 64wiRPikiPw2Lik0L6m2wy6y4yi NPwmwRmLm20LgBRmg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":65,"i_im_id":4252,"i_name":"PPky 6Bgk0 R0LNLLR204L","i_price":27.36,"i_data":"iPywig0m2mBwBB Bg2RiRwLg6kk2m i6w00wwN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":66,"i_im_id":5759,"i_name":"LiNN2k0NyBP66gLmy","i_price":70.12,"i_data":"RPwgwmwLkLPgkk42Rg4 4BkBim"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081179,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081179,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":67,"i_im_id":3313,"i_name":"2LmP2Rwiki0gRw","i_price":73.27,"i_data":"g 4w6Bg6iB0ky2kPg i6NmNwg6NNNi kgyPwg4NRP6NBkP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":68,"i_im_id":8174,"i_name":"PPgg0mLPLiw2 iiP PiL","i_price":62.99,"i_data":"wBiPyLw BkmLRBmRk0yLNP4Biy2BBmRRB6NBwkLB BP2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":69,"i_im_id":2619,"i_name":"gkw2BgP Nmy LNR","i_price":46.43,"i_data":"0gyPwR N Byi6kwRmL P246yiw64m kPwBLORIGINAL062662N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":70,"i_im_id":1412,"i_name":"BwiLy2BwL4gBgiNL0y0 yy","i_price":98.65,"i_data":"k4P22kw2NNkmR2NPw2g2iRy0g02w6yggR4kg www4BP6 y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":71,"i_im_id":2278,"i_name":"Rmwy6NB4y2mkP","i_price":3.22,"i_data":"iP N6BNLRgkmBgi406RLLkRwk0B00L04mi N22"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":72,"i_im_id":261,"i_name":" y6i g 4N mPgLNi2L66iiy","i_price":45.46,"i_data":"L000Pi20yNRwk62NgRw6gR yPkPw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":73,"i_im_id":2993,"i_name":"LLy02gLB0m6PiN2B0BLm40P","i_price":84.14,"i_data":"m4PN iLm2BL0i m2mi44g2L4BwykB4ym6L0P0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":74,"i_im_id":5176,"i_name":"LN4L4R2PN0wyBkBy","i_price":69.23,"i_data":"2k4B2L miwPkPRNmR26g4wPkBmymNmRw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":75,"i_im_id":4087,"i_name":"kmRyygPB0R LPRB6NLLgPw","i_price":63.15,"i_data":"0iyB2 PR0iBm4Pwik6mRkL2i66mkBii6N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":76,"i_im_id":8465,"i_name":"kP6w46LL0mwiLy","i_price":96.23,"i_data":" Ri604ky4w 2 6iR4g2iBkNwBN2N6NBB2wNBk0Nmyym4Bg4mkR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":77,"i_im_id":7478,"i_name":" 0Nk0y46NgyLgRLNNk6","i_price":11.59,"i_data":"gwimwPP6PR4gL4kwN00wLNB6R20 Li2kyP66iym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":78,"i_im_id":7441,"i_name":"Rmgk402k6PRNBLLy 4L0R","i_price":92.56,"i_data":"P0 2m604NNBR6yLw 02kNw0NP0kP2yL2PPLLRRB0P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":79,"i_im_id":3740,"i_name":"RwyP6 wwNP y6mP Bg","i_price":11.97,"i_data":"Pk0iww2RNRLBwggN40NNPi g2L4wiL2BR0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":80,"i_im_id":9922,"i_name":"R 4 Bi4y B2mN42R4PgL","i_price":45.07,"i_data":"LBwB6kL46i640m0ig6 LB6R4LiLLyiB4iwB4 yPym2PRyPmB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":81,"i_im_id":1594,"i_name":"w2PBiBLmk2yyykN","i_price":85.37,"i_data":"LRiw044 m60N2g4kyPRi 2w444N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":82,"i_im_id":1987,"i_name":"giyPmgPRLmy6NLwywL","i_price":68.65,"i_data":"6 NiyiRyNBNm 62wy2NyR2BwRNL iw20"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":83,"i_im_id":6683,"i_name":" iNLPyyyBmyBB64 yNNmi","i_price":87.18,"i_data":" ii4 0Piy giii60mN26iNygy0ByL 4iw4y i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":84,"i_im_id":1091,"i_name":"Nw42L0y6w4L6N wg0","i_price":3.97,"i_data":"Li0y66LR62k6 NLNggNwwB6y060iLmNgi600NymPLLmBLByg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":85,"i_im_id":3324,"i_name":"giNkRNPyi646yRk","i_price":96.74,"i_data":"240ig w4P4k2i06R2N0kgk4Pmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":86,"i_im_id":4230,"i_name":"w4424y2ywPw2BBP642iPw","i_price":78.43,"i_data":"Bg0BgNwBkwgP 0myLkyLmNkg P w6mBN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081180,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":87,"i_im_id":4552,"i_name":"RRg4y006w0g00w24Nw0","i_price":17.56,"i_data":"yimR0PRR2BRigikNL igNPmwiigN0y mPLm6wki6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081180,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":88,"i_im_id":6024,"i_name":"0kP6k0igRPmgkm","i_price":49.62,"i_data":"iBBwm6 4L62 w yLRRkmLgmNRP2ym2R2y"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":89,"i_im_id":9556,"i_name":"PgRPyLRRR0kP66L64","i_price":96.14,"i_data":"iPyNy 6P0NNLBimwmNR6mmgLw4BRPiR6B L 2460miRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":90,"i_im_id":5577,"i_name":"g6Ry4L26LiLLyLmmNm2yBm","i_price":26.86,"i_data":"L4mygBwy w0PL20y6mNk60P006BmR LByw4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":91,"i_im_id":1819,"i_name":"4ym RgPkP0Lmi24N4LBiLP4","i_price":97.57,"i_data":" 22ykyPRRLPwBBBN4g2262i2m4wPwgm04RNiyPw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":92,"i_im_id":9697,"i_name":"wPyByR N N2wP64N","i_price":9.39,"i_data":"wN6ik06Nk BymLNwPL6NP0PR26By0LBPkkRNR00i m0w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":93,"i_im_id":9447,"i_name":"4iLi20wi4y2iNwmBN4NiL","i_price":91.18,"i_data":"6wRL4i42kywiLm4gL06 mBNNLim4ig46gkmPPmBgk22"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":94,"i_im_id":3357,"i_name":"BNR06R6wkNy64By0i 4","i_price":82.1,"i_data":"kBBwNyR4L24kkmw4wgkiB6BLmiL0R4PPLN2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":95,"i_im_id":7023,"i_name":"NywmykRkL2NgNBkL","i_price":30.84,"i_data":"LgkR40B0gk0Lkw4yP 6P2ORIGINALLiPBw2km44ygNR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":96,"i_im_id":9215,"i_name":"iR66NBPywRRB0LL","i_price":38.95,"i_data":"L mP4BL0 2RRLiL64 y6y4ywB2P wPgN RP4B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":97,"i_im_id":7458,"i_name":"Nw62LNPBBkPB40LNm0ky","i_price":36.07,"i_data":"NP6Rk 4PkBB6PP2Pkk2 m4R4PN62yRP24R2LmBm66m2mN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":98,"i_im_id":2163,"i_name":"i64NiBBBN0yNwN4NBi","i_price":44.48,"i_data":"gR4i2 Pikgk 24Rg6ymL Byy 4Bg2RNim006NLBy26miP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":99,"i_im_id":3853,"i_name":"g2k2mPLLNykLwmiLwk","i_price":89.45,"i_data":"Nki 4g0LLmwBNwiwgNBLBwNRyRgB2R4N B02imPik0m6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"i_id"},{"type":"int32","optional":true,"field":"i_im_id"},{"type":"string","optional":true,"field":"i_name"},{"type":"float","optional":true,"field":"i_price"},{"type":"string","optional":true,"field":"i_data"}],"optional":true,"name":"postgres.public.item.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.item.Envelope"},"payload":{"before":null,"after":{"i_id":100,"i_im_id":205,"i_name":"0Nw24w4L4RNwmg02yNB42LLL","i_price":80.83,"i_data":"P6ikNiRN2Nmw6mBg64kRRy0P2gNmNwkBym N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081181,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"item","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081181,"transaction":null}} diff --git a/scripts/source/test_data/tpcc_orderline.1 b/scripts/source/test_data/tpcc_orderline.1 deleted file mode 100644 index 22105a1614d40..0000000000000 --- a/scripts/source/test_data/tpcc_orderline.1 +++ /dev/null @@ -1,335 +0,0 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":16489,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":42.0,"ol_dist_info":"RPN2 Rmigk66N0wi2LPiy Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":41270,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PRgyyLRNmRywRBNBNPNw6NP0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":1730,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" NNNB64Ly i4iRw k6RkL2PB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081193,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":95420,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":" k6kw6P0wBL4ggL0B4LmBL42"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081193,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":8186,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mgg2yiRLim B0g2RLN iy0m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":21.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":60815,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2yiP4PN46m2w6g0gBN iwRk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":2117,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BNkg Pkm2Ry266R0RBRi i m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":2883,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mk6y24kmmwPwyL4Pi RLNg06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":25700,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.21,"ol_dist_info":"24RBg0N 2Ng 4ym0yyP RN64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":13643,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"miNN6g4imkgm kgBgRmP N w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":3460,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":5140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wgwikiykN6wRmk0RmkLR4kRw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":62964,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"6 gP 62LPR Rm Ni2g442P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":4036,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gRw0kgk4g k6Pywki4Rk4L6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":55980,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w B004Lgk4N2NN40m00P0626"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":19100,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"k6i PkkPikR60gg6N2imByNN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":49466,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ymgy w6RLRwymiLPmiRgP0RP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081194,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":23810,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RB4yBiBimR wB4LPmLgPwmm2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081194,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":5189,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2gNLRk y2LR 6BP gyP060k4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":86260,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"6mmkLgR4L6iwL2 02Bi40i60"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":24557,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i0PmwgykgiyRk2mLig6Lwk2m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2105,"ol_d_id":10,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":3460,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081195,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081195,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081196,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081196,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2106,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":3460,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081197,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081197,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2107,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081198,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081198,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":3460,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081199,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081199,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081200,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081200,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081200,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2108,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081201,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081201,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":3460,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081202,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081202,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2109,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":88652,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NiB6Lk22yLiw 2w 4 NyyBRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":21694,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iPRg2m24kR2mmRLPgigyP2Ly"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":2307,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 2 6P2g4 62NyPRLPPR6kBiR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":60560,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pgm w0PmPk0Pyw40wNmmim64"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":10914,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RP0ygLk2LPimRR4i0gB24ykP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":1,"ol_i_id":32977,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" w m0 B wyik ggykyLPkiRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":2,"ol_i_id":82540,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NBN64wBBRR20BkP6 N ik w0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":3,"ol_i_id":3460,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m RP66gNm2 gPBi0NkRyw4wk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":4,"ol_i_id":90840,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"iL6Lg2N2gmwiwNN0kgy kw06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":3,"ol_w_id":1,"ol_number":5,"ol_i_id":16371,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PLyk6R yPP06iNkNw g 4i 6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":1,"ol_i_id":77303,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" RkmwNk6my gim0gigR646RB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":2,"ol_i_id":43387,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yyBN6 k2yR4 RPLwL N4N4ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":3,"ol_i_id":4613,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"062kyiwg264R4wBwLNP6ykPP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":4,"ol_i_id":21120,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LwR206LByw2Nk2g0gR P 40"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":4,"ol_w_id":1,"ol_number":5,"ol_i_id":21828,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Py26NNN4NNPRB i 2N4664Nw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":1,"ol_i_id":21629,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m4kBL0NB2k 4ikL6y6PgR2RN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":2,"ol_i_id":4233,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2 yw0RL kR4m6kB2R4RPgBi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":3,"ol_i_id":5766,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Pwk44mwRPiBimy2RRiPNPN2k"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":4,"ol_i_id":51399,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"m2BkLiRi4Pyg2kR04kL2BR62"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081203,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081203,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":5,"ol_w_id":1,"ol_number":5,"ol_i_id":27285,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NB RmB2BBNyB2wy4yRRw0P02"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":1,"ol_i_id":65954,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gi2Bgmm00kRL0yw4w4NyBRR6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":2,"ol_i_id":65080,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PmB422m6RP62mNyk2R2BR0i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":3,"ol_i_id":6919,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"B2BymkL Bm0LwkB6RLPmR2gN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":4,"ol_i_id":81679,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PNkLwmP6wR2R0 0LN4iR2i4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":5,"ol_i_id":32742,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Nw4w4yg6yL6mB wP22N22Bgk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":6,"ol_w_id":1,"ol_number":6,"ol_i_id":23009,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ByRwNk20mPiBmmmN4P0mRkk2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":1,"ol_i_id":10280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"gw2RwB4yR4R RwgNBNLPgyRi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":2,"ol_i_id":25927,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kiyN244NwP6 iBRmwggky2g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":3,"ol_i_id":8072,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"w 0iNwL2yiw6Nm2BPgPN0yki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":4,"ol_i_id":11959,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"ii42iiNNN0ykRP20 ggy06m6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":5,"ol_i_id":38199,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"LkBiLwwwBLP42wLm mB 4mBR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":7,"ol_w_id":1,"ol_number":6,"ol_i_id":60177,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 0m6gRy2yNkR2BLB4N0iRBmw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":1,"ol_i_id":54606,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2BLR0Pw4 60wRB0NRLB60mRm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":2,"ol_i_id":86773,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4kmB4gwkkP0gPLygy0 0N24B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":3,"ol_i_id":9225,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"i6kNk 0Lkm2 2imRNRNmkLyL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":4,"ol_i_id":42239,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"L2Pk2kLmki2Py6N0wBiL0ggg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":5,"ol_i_id":43656,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Rm64B R0 RwPkiR64 g640Rg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":8,"ol_w_id":1,"ol_number":6,"ol_i_id":97345,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"yBPy g24wL6RwP0g6LRmR6iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":1,"ol_i_id":98931,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"2PL6g26BwRgk PLwPB wNgRy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":2,"ol_i_id":47620,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":" 6ik6y6RRP024gwwBNLNi P4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":3,"ol_i_id":10378,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4LBwBw0m6yy0k4NmLmN2mgLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":4,"ol_i_id":72519,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"4 wNwB2Lkyiwmg2k4B0i ki"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":5,"ol_i_id":49113,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RiwPiw6ywRm LmRB L4L6L4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":9,"ol_w_id":1,"ol_number":6,"ol_i_id":34513,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"BkigLyy4 B0662y46BByRwm6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":2110,"ol_d_id":10,"ol_w_id":1,"ol_number":1,"ol_i_id":43257,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"P2w6LgP6mLg0 Nwm4kyNy4RR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081204,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"orderline","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081204,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":72163,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.459838+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"PBN24wNLik4iN2Lk2NR0LLR4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24379984\"]","schema":"public","table":"orderline","txId":1325,"lsn":24379984,"xmin":null},"op":"u","ts_ms":1664141081512,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":80424,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.459838+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"kPkRwBigPRwPB6R4BkBLLgPy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24387432\"]","schema":"public","table":"orderline","txId":1325,"lsn":24387432,"xmin":null},"op":"u","ts_ms":1664141081512,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":577,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.459838+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"Ngwi424iLwLB0P44mBRLByB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24387832\"]","schema":"public","table":"orderline","txId":1325,"lsn":24387832,"xmin":null},"op":"u","ts_ms":1664141081512,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":65140,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.459838+00","ol_quantity":5,"ol_amount":0.42,"ol_dist_info":"6Pm0L2Rk4 gBi0i0NB 6 00"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24388208\"]","schema":"public","table":"orderline","txId":1325,"lsn":24388208,"xmin":null},"op":"u","ts_ms":1664141081513,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"after":{"ol_o_id":2105,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":2729,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.459838+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wkLgRmBgmmRR k2kgBLLwg6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081461,"snapshot":"false","db":"ch_benchmark_db","sequence":"[null,\"24388584\"]","schema":"public","table":"orderline","txId":1325,"lsn":24388584,"xmin":null},"op":"u","ts_ms":1664141081513,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.466051+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24411248\"]","schema":"public","table":"orderline","txId":1326,"lsn":24411248,"xmin":null},"op":"u","ts_ms":1664141081520,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.466051+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24411488\"]","schema":"public","table":"orderline","txId":1326,"lsn":24411488,"xmin":null},"op":"u","ts_ms":1664141081520,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.466051+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24411728\"]","schema":"public","table":"orderline","txId":1326,"lsn":24411728,"xmin":null},"op":"u","ts_ms":1664141081521,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.466051+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24411968\"]","schema":"public","table":"orderline","txId":1326,"lsn":24411968,"xmin":null},"op":"u","ts_ms":1664141081521,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2106,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.466051+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081467,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24410952\",\"24412288\"]","schema":"public","table":"orderline","txId":1326,"lsn":24412288,"xmin":null},"op":"u","ts_ms":1664141081521,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.469611+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24422592\"]","schema":"public","table":"orderline","txId":1327,"lsn":24422592,"xmin":null},"op":"u","ts_ms":1664141081522,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.469611+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24422968\"]","schema":"public","table":"orderline","txId":1327,"lsn":24422968,"xmin":null},"op":"u","ts_ms":1664141081522,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.469611+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24423344\"]","schema":"public","table":"orderline","txId":1327,"lsn":24423344,"xmin":null},"op":"u","ts_ms":1664141081522,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.469611+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24423720\"]","schema":"public","table":"orderline","txId":1327,"lsn":24423720,"xmin":null},"op":"u","ts_ms":1664141081522,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2107,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.469611+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081470,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24414152\",\"24424096\"]","schema":"public","table":"orderline","txId":1327,"lsn":24424096,"xmin":null},"op":"u","ts_ms":1664141081522,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.47275+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24442448\"]","schema":"public","table":"orderline","txId":1328,"lsn":24442448,"xmin":null},"op":"u","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.47275+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24442824\"]","schema":"public","table":"orderline","txId":1328,"lsn":24442824,"xmin":null},"op":"u","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.47275+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24443200\"]","schema":"public","table":"orderline","txId":1328,"lsn":24443200,"xmin":null},"op":"u","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.47275+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24443576\"]","schema":"public","table":"orderline","txId":1328,"lsn":24443576,"xmin":null},"op":"u","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2108,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.47275+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081473,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24434008\",\"24443952\"]","schema":"public","table":"orderline","txId":1328,"lsn":24443952,"xmin":null},"op":"u","ts_ms":1664141081523,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":1,"ol_i_id":44326,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.475677+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"N4R6g6 wPL0PR4LR6RPgNNR2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24454392\"]","schema":"public","table":"orderline","txId":1329,"lsn":24454392,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":2,"ol_i_id":60847,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.475677+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"wNN 02 yyR0y6mPi4w4LmwLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24454632\"]","schema":"public","table":"orderline","txId":1329,"lsn":24454632,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":3,"ol_i_id":1154,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.475677+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"NwiBi40BN2ykgNigRmRy2m4m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24454872\"]","schema":"public","table":"orderline","txId":1329,"lsn":24454872,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":4,"ol_i_id":30280,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.475677+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"mwBiL4Ryi2wmPgB0Pk262222"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24455112\"]","schema":"public","table":"orderline","txId":1329,"lsn":24455112,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2015-11-22 00:00:00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"after":{"ol_o_id":2109,"ol_d_id":1,"ol_w_id":1,"ol_number":5,"ol_i_id":5457,"ol_supply_w_id":1,"ol_delivery_d":"2022-09-25 21:24:41.475677+00","ol_quantity":5,"ol_amount":0.0,"ol_dist_info":"RNwL P6wPRBBiN6ww4Nw2L6i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081476,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24454096\",\"24455408\"]","schema":"public","table":"orderline","txId":1329,"lsn":24455408,"xmin":null},"op":"u","ts_ms":1664141081524,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":42,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":126.35,"ol_dist_info":"0w420By2wmgimLRP6 B2g 6R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24472784\"]","schema":"public","table":"orderline","txId":1330,"lsn":24472784,"xmin":null},"op":"c","ts_ms":1664141081529,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":43,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":323.34,"ol_dist_info":"N406B446gL2mgwBPw0RL4gRg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24474432\"]","schema":"public","table":"orderline","txId":1330,"lsn":24474432,"xmin":null},"op":"c","ts_ms":1664141081529,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":44,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":630.42,"ol_dist_info":"g giRRwRyLiB0PyyBy0y40Bm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24474624\"]","schema":"public","table":"orderline","txId":1330,"lsn":24474624,"xmin":null},"op":"c","ts_ms":1664141081529,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":45,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":87.04,"ol_dist_info":" 2wBgw04RRRkiB040iy026mN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24474816\"]","schema":"public","table":"orderline","txId":1330,"lsn":24474816,"xmin":null},"op":"c","ts_ms":1664141081529,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3011,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":46,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":151.11,"ol_dist_info":"B06NLP2NiR 00iw6N PiBmwi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24475008\"]","schema":"public","table":"orderline","txId":1330,"lsn":24475008,"xmin":null},"op":"c","ts_ms":1664141081529,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":1,"ol_i_id":47,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":5,"ol_amount":451.1,"ol_dist_info":" 0k6B6g0N2ikkB0NPLmB2LLN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24493200\"]","schema":"public","table":"orderline","txId":1331,"lsn":24493200,"xmin":null},"op":"c","ts_ms":1664141081534,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":2,"ol_i_id":48,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":6,"ol_amount":529.2,"ol_dist_info":"62k4g6BNNBmm0B20i L2y2i2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24493392\"]","schema":"public","table":"orderline","txId":1331,"lsn":24493392,"xmin":null},"op":"c","ts_ms":1664141081534,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":3,"ol_i_id":49,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":7,"ol_amount":396.9,"ol_dist_info":"0L4 Rw2k0gPB4gy4gPBiLmm0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24493584\"]","schema":"public","table":"orderline","txId":1331,"lsn":24493584,"xmin":null},"op":"c","ts_ms":1664141081534,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":4,"ol_i_id":50,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":8,"ol_amount":317.6,"ol_dist_info":"4Ry wRPP6kkRN6 Nw 4LN4k0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24493776\"]","schema":"public","table":"orderline","txId":1331,"lsn":24493776,"xmin":null},"op":"c","ts_ms":1664141081534,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"ol_o_id"},{"type":"int32","optional":false,"field":"ol_d_id"},{"type":"int32","optional":false,"field":"ol_w_id"},{"type":"int32","optional":false,"field":"ol_number"},{"type":"int32","optional":true,"field":"ol_i_id"},{"type":"int32","optional":true,"field":"ol_supply_w_id"},{"type":"string","optional":true,"field":"ol_delivery_d"},{"type":"int32","optional":true,"field":"ol_quantity"},{"type":"float","optional":true,"field":"ol_amount"},{"type":"string","optional":true,"field":"ol_dist_info"}],"optional":true,"name":"postgres.public.orderline.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.orderline.Envelope"},"payload":{"before":null,"after":{"ol_o_id":3012,"ol_d_id":2,"ol_w_id":1,"ol_number":5,"ol_i_id":51,"ol_supply_w_id":1,"ol_delivery_d":null,"ol_quantity":9,"ol_amount":875.52,"ol_dist_info":" PmPgwLyk 4mRRPR0 k2NPi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24493968\"]","schema":"public","table":"orderline","txId":1331,"lsn":24493968,"xmin":null},"op":"c","ts_ms":1664141081535,"transaction":null}} diff --git a/scripts/source/test_data/tpcc_stock.1 b/scripts/source/test_data/tpcc_stock.1 deleted file mode 100644 index 1958aafc8095b..0000000000000 --- a/scripts/source/test_data/tpcc_stock.1 +++ /dev/null @@ -1,110 +0,0 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":1,"st_w_id":1,"st_quantity":10,"st_dist_01":" Pkm4N 6Rk0B4L6L iNwRRN","st_dist_02":"L4PN 406kNP0B0Nm4R4gRg2B","st_dist_03":"0 PyLiw4N0iLmBNB60myyw4B","st_dist_04":"LiPgR4NN2PRk2L 4gikBNkRy","st_dist_05":"2NRgLLPiPkBN iRyB4Nw 4y","st_dist_06":"RBRykPgiL4B ggwwyyBNN0Pi","st_dist_07":"006kiw0P4iBLwL gi2m P4kP","st_dist_08":"B g44m2kykkRgk2gPi NyiL0","st_dist_09":"B0R 62mLmyBBw mLLgP4kRy4","st_dist_10":"imPk4k0kg NiLgmw4LigiPBy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"P0k gNLim22 2RiPN20ykm24yB4iBLiiRy2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":2,"st_w_id":1,"st_quantity":53,"st_dist_01":"ikkw4myP6ki64iBy62RggLLB","st_dist_02":"wN2g4y2NBP62BN6BB0wPm0BR","st_dist_03":"k4RLRPLPL4LwNkyy 6iiyB2P","st_dist_04":"LB 4BBRgN2yRLi P22iLwRP","st_dist_05":"gN4iyRg 4mNB6i0Lgk2Nwgw4","st_dist_06":"i6mN04www44R4yPPw2 6P242","st_dist_07":"BPi6 NiNw60P424gkg2P 0iy","st_dist_08":"LBg2myR 2L20myiLyyBkPikP","st_dist_09":"wL44wmwPgk Pmg066y4y606L","st_dist_10":"wBBPwR660N6NBmm6L62RwiNk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"w0B4w 6i6yPiL4kmBL46 gyRmm kw4 ym46PBwi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":3,"st_w_id":1,"st_quantity":35,"st_dist_01":"m4BgLBPB064yRw4ki2g62y0B","st_dist_02":"06 gR2gNim0 PmBmR2 NgBi","st_dist_03":"PNwiPgm6L2R4iBR LN2wByPm","st_dist_04":"6gRR2BiNg426 B6i26Lw200","st_dist_05":"42BkgPNLiwyyB L B44iw2Bk","st_dist_06":"gmykL4wNPkP6gkNym0BLRPP2","st_dist_07":"kRwmik2iLB ig BmkPPNmRiy","st_dist_08":"2Nmyg0BB 26ikiPi0gB0NBmi","st_dist_09":"LgkRNiiNRRPmkRNw40NmR40P","st_dist_10":"kkw04Bggk00BkLB20iRLLN6w","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kkwR4kB6 404mgLw6RRNLiRk0g4206B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":4,"st_w_id":1,"st_quantity":63,"st_dist_01":"LyNLP N6Pyw2RNm0wk6m NBL","st_dist_02":"gg2BNLw24 iP0ygNBg4iBBgR","st_dist_03":"iN6wR 42L0PikPN Ngm gP0L","st_dist_04":"w4ii44BPk66BkiLi6LiP0wPL","st_dist_05":"gNwB2NPBB6wiRm0yRN24kyL4","st_dist_06":"gPRwRkBwiyiP4wR kmyPB00m","st_dist_07":"w6m2g ykNRiR6NR6kP06mwyw","st_dist_08":"RB6BgywyRP4g gm P4k w6Bw","st_dist_09":"NiyBNBRw iPLgggNPgLRikR6","st_dist_10":"RP i42y4i B046ggNmiBR6g0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NB2g0iNB NLy0L6BLPBwmN02gBi4iw0R"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":5,"st_w_id":1,"st_quantity":94,"st_dist_01":"iL4Pg4gw Lmy6NLkBLLigkB2","st_dist_02":"mkyy64N44yyRiw26 LRk4wP6","st_dist_03":" g4RkmwgPRR2446PBRmmP kw","st_dist_04":"6RLwLLw2P4BBkkimgyB60Py6","st_dist_05":"6w6NmB4kL g6BL6kRk66iLBL","st_dist_06":" 0N0PPRkmLPmkLw64iRRwBBi","st_dist_07":"kkyRgwgRi0Lgwik6 iwBNmRR","st_dist_08":"BNBg0k6gN0RRmm4Pw6ww4NL","st_dist_09":"224Ngykwg402Bmyig064BgN4","st_dist_10":"i R2wmwyLNP4BwmkNmN04yy0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"L2yBRLORIGINAL Pmkyk42RyyB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":6,"st_w_id":1,"st_quantity":83,"st_dist_01":"mmw6wi 46 0w4R2kBR mNR4g","st_dist_02":"iPwLP6Ng0NLRwN 2i0R0L04y","st_dist_03":"m4 2R042g42y kgky64yw0m4","st_dist_04":"20gRmm2i2Bk64BPR i kNPiP","st_dist_05":"y460 ywLPy2P2Ri6mRkRRPR","st_dist_06":"6kmyi RykiPL2N0Ly6RL0w0k","st_dist_07":"wkmyg0NR20PBPi2Pm L4N i4","st_dist_08":"Ry04gNNygNNR2w0ggiwk600N","st_dist_09":"Bgy0P4LNLR0i20BPN2B4kBR0","st_dist_10":" N2NRLy6i0kR4PRgPmk04kPi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" 2y 0g0B gk2NwLRmwkR0LNPwgLP4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":7,"st_w_id":1,"st_quantity":48,"st_dist_01":"6BB6NR 4Bi 0BBL64N2Ng262","st_dist_02":"6gm2kkw62P6yLk6 mR4LN0BP","st_dist_03":"ywP0kRRwy2R660wNLRBi ymk","st_dist_04":"4Biywgk6 NwL 60LRiRig2 g","st_dist_05":"km0642iNwg4BL24k4wBk6Lgi","st_dist_06":" yg PmRiR60RPNgm4NyByN g","st_dist_07":"gmP mkmL24LwBy04N BR4 i","st_dist_08":"yiBk NB2N6RN6Bm4N6R0RB2N","st_dist_09":"wyP2ikg64kikNN4Bi2RRLRgi","st_dist_10":"imNBk6PL4wLkR6NgimwRL2gP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0BwN6m iBkP4yii64y0R Bmym2N2gwmw 6kgLw wPgPiL20B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":8,"st_w_id":1,"st_quantity":26,"st_dist_01":"2Bg6RRRwkN4NgimR22mNPR P","st_dist_02":"i N4kRg4PP40NLy4i206B","st_dist_03":"B PLP4mPyN00NRPkw 2Rwy2B","st_dist_04":"BwLkkikmwyw i44wPy0gyR4g","st_dist_05":"ii4g40m4mR6244kmwiwm2L0k","st_dist_06":"PPLkw24wR mk0B0kkm4L iN","st_dist_07":"RB6y k NmR4ywLN0B64Nmkw6","st_dist_08":"iggmg64miwm0P 6PL2PPLBii","st_dist_09":"02mmiyg BkL4i4Lk0N PP0R","st_dist_10":"Lm4 L6NPmNkBR0ykgmm0LL 2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wR26 L2406Lk64Lwywk44Bk42kN6gL2B06NgL6PLgwmB20"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":9,"st_w_id":1,"st_quantity":76,"st_dist_01":"RiB2BBBmmm4 ByBPi2ikiB i","st_dist_02":"BNBN0NkB 6mk4ymwN0w4k2gR","st_dist_03":"wkgB0mgLBwNi 642 6kN00g2","st_dist_04":"L4yRmmPkkBB2k6y R46RLRPR","st_dist_05":"N2im666iygLiw0iw ymigRiB","st_dist_06":"NwPmg40PBgyik Bmy w4ywL6","st_dist_07":"kiR6myPwkP0PgRkmkw42y k0","st_dist_08":"PPiik2ym2LkB4yB220B4m6wy","st_dist_09":"k2mmgwRky4kw6 iwyy4Py602","st_dist_10":"mRy iPP6Rm44gmw mwgimBRL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" N yyk4iN4B ym0P2Nymy Lmk446g0yBR NmBPyL20gR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":10,"st_w_id":1,"st_quantity":29,"st_dist_01":"yP Nmg0RRRL0Rymiyg 2yNL","st_dist_02":"6yg4imy gwNB466kLP Nk0Rg","st_dist_03":"iRBPk NiBw64iL w2w gL2Bw","st_dist_04":" kNiN2mR2By2N00k ik4igPy","st_dist_05":"24gkyRmg4iiyiyR4 0R L i","st_dist_06":"gykRgig6yRL424LLy4R62m","st_dist_07":"ByN2Lm6 gy406BkL kk2mPy4","st_dist_08":"PLPNL6Ngm 62wByBLiBi2iym","st_dist_09":"yi LBPmP40Pi g4gg6mPk4my","st_dist_10":"Pmi24kP2LRiiPmwBw2BkB6kg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RmkLLNy6LgNNiiR2BkL2BL0L6imgmgmLwRR0Lg4yP26B"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":11,"st_w_id":1,"st_quantity":62,"st_dist_01":"40mBgLRL0PLBN i6wkLNy2PN","st_dist_02":"iR4y0ymg64RN4gy2PwRkgmNR","st_dist_03":" 42Bk6RNR06i0 B44B4 RgNN","st_dist_04":"iim64 L4igkP mi4Rwy0B0yy","st_dist_05":"k260BL0kL4i40kNLL2mi0 0","st_dist_06":" w6m26kgBk2iLg6Lk NRg40m","st_dist_07":"N0wmPNyRm220kBi0yBymk206","st_dist_08":"w4wmP02m00gBwP2iygkBRmg6","st_dist_09":"gi w404ky4BP4kimPB2k0 R4","st_dist_10":"mg0B2gmyL2mmkLRw6gRkyyR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iN2iPRNNmkB62kPPNPN40Ly 4BR2Niik6P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":12,"st_w_id":1,"st_quantity":40,"st_dist_01":"2m wBL2wyy 0kmLN6m6wi42m","st_dist_02":"BL6P4L4P2Ni 2i02666BL2kg","st_dist_03":"0NP2L LiiNN ii22wN6RL0P","st_dist_04":"L02iRi4RRLRwkLNmNP Nggyk","st_dist_05":"2NgNmw46iLyN4LPPkgi6kgyy","st_dist_06":"kNwgy RNg22gyik6kB6i04Rw","st_dist_07":"20NLByB2000mNBm0ky22 226","st_dist_08":"BR4w6PikRLNBwi4 4gkgB2k","st_dist_09":"P 4P2RBkPyg462iim0mmgLwP","st_dist_10":"2iw4B 4wNLB6k6yBB2k4LRL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BRBwRwmBL kymymL4ygmL24g iLk0 4iLmBgw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":13,"st_w_id":1,"st_quantity":71,"st_dist_01":"P LmPRygg2 y02NmyL2LgyL","st_dist_02":" 6y0w6k4mR6k 06g2LmNmmgP","st_dist_03":"6Lg2 L24y4NyLNmy2g60yyiw","st_dist_04":"ki04N6ky6g42yPyBBNNwkNLL","st_dist_05":" 4ykB Py2iLPg2B2ikg0R P2","st_dist_06":"Bm6mw0LL6062yy0yBPB0PkL","st_dist_07":"0 m6i2yR2im RLy0iN6i0 PR","st_dist_08":"6N2yRg0P0mB6gPw0ymBNR244","st_dist_09":"P4m2Nmkm0m mk2kww4k2NgyP","st_dist_10":" w2LPki6k 2kNg4B 0imNRk4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Pkkykk2kwkgk 66 Ly6R6Lm24gmLkw6iLR0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":14,"st_w_id":1,"st_quantity":75,"st_dist_01":"RwiLiRB4k66RR04gPRwy24iy","st_dist_02":"N22wki w462BRw24PR2P6kN6","st_dist_03":"gNyNPi2g60m4NP04LNPL6PNN","st_dist_04":"446gRm0N6wPR40y44RN24P26","st_dist_05":"B Big0iBLL4ywRkBLN6wLgBg","st_dist_06":"26kR0PN4i Bgyk4yR2i46 0B","st_dist_07":"RkP 0k0ggmN6m0 4LL ii0B0","st_dist_08":"4LgmyNww RLkN2yNgg2yPN y","st_dist_09":"yR NL6Rgm gLP0PRRLkm2wk","st_dist_10":"gww0k6wLNPwyywB0Lgm6ym4y","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6BB i 4kkgm B2Bm4g4gLkRNiyi0L6yB2gkL0Pi06LN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":15,"st_w_id":1,"st_quantity":60,"st_dist_01":"yw6B P6ii4m0w6P6Bi2NygBP","st_dist_02":"P4RRymw04B2LmLiByy4gkB6m","st_dist_03":"iBR LwLRPgy04R6L2gkg2B B","st_dist_04":"i24i26i6LgkggPyRywkg6wLk","st_dist_05":"Pm 4 6kwBN0R2y6L646my0P","st_dist_06":"giPgmLRyPPgBBLRyP00N6RBP","st_dist_07":"4kgN BwygiwyPk0L 4Pmk LR","st_dist_08":" 6Bg2Rkw0LmRwkNw k2k4P","st_dist_09":"4 i06P g40wwNk64wg2L260","st_dist_10":"6N k4Pk466ymiR2R0i LiiPw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"y624 PPg2L666g2 BgLLBkRiPmwPPwwkwi6ym"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":16,"st_w_id":1,"st_quantity":31,"st_dist_01":"i60ygiy 0NiB Nk24LPNRmkP","st_dist_02":"6g Nmmgy iRgL2ii4R2k m2","st_dist_03":"2wBiNRy i4mkw 6w4kk yi","st_dist_04":"PRgm0BR Rg6mPyR0kPL2gggN","st_dist_05":"iy0R 0iBBBgPmwR02NBkiwg0","st_dist_06":"ywPLwgRi00i4 Pk 6ykwg42","st_dist_07":"6k0 P wiNwBPmmykkwiBN06","st_dist_08":"2y60y2 w Nk 6ygwBkm0P0N","st_dist_09":"wgm66kNymik2PBkLmB0L4ikP","st_dist_10":"k0 0RBBNyP46mBmPiyL2kBiL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"i gPLk ygm6mmw 0N0B262yyNNPR0k6N66yw4mk6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":17,"st_w_id":1,"st_quantity":10,"st_dist_01":"NPygL62g4gk20B4k2NiLikNy","st_dist_02":"wywyPBPmy2kLi4RiLi6 mP i","st_dist_03":"kP0ykmNy4k6LLBBBRR6R0y0k","st_dist_04":"y022yPiiPg6 02iykRmy6wyi","st_dist_05":"6Ry 2264iNP4046g 4mP6y2","st_dist_06":"gLByBmBi0RwL RL6L4LkLw6","st_dist_07":"gmB6Nw0BLRw0 0iLByNwg2wN","st_dist_08":"BiRRBLkgmiPBkBkB4wi4L2gy","st_dist_09":"4m2B wNiPgig B LBk4RB g","st_dist_10":"B24ykyN gR4ki4yPmk060R66","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0y 0L BP2wmmmw4ymkB2PkyRRiw0LR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":18,"st_w_id":1,"st_quantity":23,"st_dist_01":"By y6P2BmBywPwkRyBPRRN 2","st_dist_02":"2Rww 4k4gPmPikwP4mw 400B","st_dist_03":"w60BiyR L46iNw0wm6PR gwB","st_dist_04":"kgwmk0Pgg6Nm6myB04kgmkkw","st_dist_05":"R0g2PNk2kNiLkB6RyyB2NLkP","st_dist_06":"kw6gBiwmk6g6w PmNgwP240k","st_dist_07":"PRkwNPR0N2BRNB6mkLgk0Ngm","st_dist_08":"w0gg6i2g6Ny20 i6 giNLwkw","st_dist_09":"km gB0Pk00mgN2gi iiRRwRB","st_dist_10":"BgBPg RkkBmyk4B0Li20mw0k","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"62m 0NygP0PmRyBBB4kP0NR2B60iLki6Li"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":19,"st_w_id":1,"st_quantity":50,"st_dist_01":"mw 0ByLkBLRLgBNR00km0PLB","st_dist_02":" wmLyLLRL4y NwNB0NN4iB4","st_dist_03":"P2kwgRyLiBwB2i6Biwwi 4 N","st_dist_04":"6ig2k2 24w00NgwwPBmy6B6B","st_dist_05":"ig2g w4RR6wNg0wLL4BL4Pig","st_dist_06":"6406kwkL2g0k0BRm26ygPNgR","st_dist_07":"ki0P6LRyLiwi6y2BymPkB2w0","st_dist_08":"mPwPk 6kyP6Pw 0N2RP6R6k","st_dist_09":"2Rygw0PNPRP2NR42PwNwNBLg","st_dist_10":"64kN26NLi2m4B yN40LRwiBy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4gPiPwkByy40PR24iL24 kk4 NkBRw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":20,"st_w_id":1,"st_quantity":86,"st_dist_01":"4Lk4RgiLL wywgNwimk gg42","st_dist_02":"PLgPw2RmLNPkwL LggiRLwNN","st_dist_03":"6LLmwRPRgP6y6R PPkiPg BR","st_dist_04":"w264ygg62RLP2yy6Bm RL0Bi","st_dist_05":"2ki2myLwByNPg6624LmwBmLy","st_dist_06":"2wk64m0kR4gB6 2Bmm0Nm2yi","st_dist_07":"y k20iP462 g4mPyL64gg226","st_dist_08":" iB24LgLm 2PNmi2gww46Bg0","st_dist_09":"yB6466y62BLiRRiwNB4B64Ng","st_dist_10":"LyNyBikmiwwiwymBik4 4 i","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"26NwL22P L0Rw6 0B2B0 kk62PyywORIGINALLBgmi04RkyR"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":21,"st_w_id":1,"st_quantity":58,"st_dist_01":"wR4mPmPB6y0P64iBiiBPwNPL","st_dist_02":"RLPmPN00iRmw6wyP22NmRL4k","st_dist_03":"Nm 2NL mL2 gB4mNBN kPL P","st_dist_04":"imgwB2k4PiiB0gB22m m2m26","st_dist_05":"yP4g RLww62w6imk2 kk64","st_dist_06":"wwRLyRkiBBPN424kgyRm6 B2","st_dist_07":"wR6LLiNkPw22kN iB2y gkLB","st_dist_08":"kNNiBk0NNLN ikwm mm gRmk","st_dist_09":" 4PiR0 N4kwR2mkLkNg0PyLg","st_dist_10":"2 ggR4RPNPi64LPPPygP0iN4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" 4PmPygyyNLiBPL0k4NPgwg6P4w4gwyB46w"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":22,"st_w_id":1,"st_quantity":38,"st_dist_01":"mNN4w6km6BPmgL NL4g2RLy2","st_dist_02":"Lwk06 40wmw wy20kgRBLgw0","st_dist_03":"w gyNPmiP4g60k4Pmw42L Nw","st_dist_04":"Pk6kN yPiiBwBm0i6LwmLL4P","st_dist_05":" RPy6Pmy2gkNLgw2Nkgii2Rk","st_dist_06":"m4ggg gPyRBBBwgBmk y 6yN","st_dist_07":"LB6LiBR4R0y4RBP6BBRgLmw4","st_dist_08":"iP44PLN0 NgyR60mk6wkw w","st_dist_09":"mLR2Rm4L26Ny2P26PR BiNyR","st_dist_10":"g4 wiL0iy06L0PwkPkPg4iRw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Rk2gLwBg6Pg26N6B0 yg PNRBLykyyBw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":23,"st_w_id":1,"st_quantity":21,"st_dist_01":"06L R64LwmwPi4NywPLLy0i","st_dist_02":"Ny4im4g02464y 2Bm2iLLy4k","st_dist_03":"B6ywR4ykRgPiPBwBR Lgk6L","st_dist_04":"R40ig42mmik4Pi420gN6BPBw","st_dist_05":"P6w BB46yRwPi 62RN0R0LL","st_dist_06":"2R2NwwwkPBPi2w6g40 w0By","st_dist_07":"w6BP PikkBi6L0NLymLP4P02","st_dist_08":"4Lg6RRRRmB442yPNgwP40 4","st_dist_09":"PmNw4PNLkmkBNR4BRPm mLRN","st_dist_10":"mk0BiNkPR2ymiPky4 Bi wR2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mkiPLw2iy0wRyNLPN6N k gmR2mP4N 4 kNNLNy64m40mLww2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":24,"st_w_id":1,"st_quantity":97,"st_dist_01":"i0Rym4B60y2R kR6B 2BLP6g","st_dist_02":"602m2Ri60BgRN4gm00 PRPm4","st_dist_03":"4y4Bw4m044wBk0 NB 0wwwwi","st_dist_04":"6B0Pi k66R B 02iL0 22R44","st_dist_05":"4Nywk4yRBiygRkggk4Bi2NP6","st_dist_06":"y2k00g6ky6gRk wkN64 4gPB","st_dist_07":"PmgPwN0i6i LPyyNyk P4wmw","st_dist_08":"LwNiRiP0RyNkiLPmygBm2L2w","st_dist_09":"4N4BiP6wPmLRRRNR44y0k 4k","st_dist_10":"P64NBBwgBmN60kymNN62NBm2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iLyORIGINALky6LLiB2iP62L0R6204g0yLi2 yLNNmwm0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":25,"st_w_id":1,"st_quantity":41,"st_dist_01":"NwLi 2L0mNLwy2mi0L06ywLm","st_dist_02":"k0ikiLyykwR ki 4kkRiL0mP","st_dist_03":"P4BBg4yk46 Pi4R0kB6i m00","st_dist_04":"Pmww40P6gimPLLwL4iLm0i0g","st_dist_05":"kwkmwy 6RgmP6wgN4yPmgNky","st_dist_06":"Lk6y0L6L2 2wByNBgmm60g N","st_dist_07":"BNB606i2mBkPmL PRRiR6N00","st_dist_08":"i26w yLwP iwRm62462iBw w","st_dist_09":"i 200Pw2LPw0k6N22ywPwk4k","st_dist_10":"BRyN2B Pkw2w0NRwki62 60k","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0g 6 L26gwygBLmmw6iiRi NPk0 6iP24N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":26,"st_w_id":1,"st_quantity":87,"st_dist_01":" yy i2RywNk6RRkiww6wLR04","st_dist_02":"NLiLRm yB6k66262 RmmmLN0","st_dist_03":"B4R0PRNPiP4BNm6Nk4mmkgy0","st_dist_04":"g4RR2wNm6wPwi2w4m y6giPN","st_dist_05":"w0Li4PRmPy24i42LkN2g4mkL","st_dist_06":"2gL6g2g LRm00wgyy6m40i0","st_dist_07":"wggBw0L02P6NkPikNym2P4B4","st_dist_08":"ki2wNig 2L4L N2kRPBB22 4","st_dist_09":"i40BmiB0Pw4064gRLmyyNyP0","st_dist_10":" 4mBiN N6kiNNRkkRL26yPik","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"B i2mig R2P4B20R kyi0PPiig6BBP44m0mw244Ng0LP44k42"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":27,"st_w_id":1,"st_quantity":51,"st_dist_01":"iPgLy0BBNi2yyPym4wPL22 6","st_dist_02":"k0kwPN6i2iB6wPBB2mRykmiN","st_dist_03":"By 6BLRBNwwmBP42Pgmkk46i","st_dist_04":"ggiN2k00m6g04im gRmgP L6","st_dist_05":"PwgyLRmk2244 By0i2wgLiBw","st_dist_06":"L yi4BNkkkky0NRPkBRgii2g","st_dist_07":"444BmRw04wmNNNRPi6NwRiP0","st_dist_08":"LiN04 RkBkByPikRgkLimg k","st_dist_09":"NwPP2Ly gBR wk0gB464BLP","st_dist_10":"RBigB 2g2k6wwRi4mPg0 iw2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R4k60R4Nmi2iB66w L4Bgi2wykL6gymPmi6B0LkRPw6y i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":28,"st_w_id":1,"st_quantity":88,"st_dist_01":"w wLRR26Lg y42N4642i yyB","st_dist_02":"PRigy0gB44P2PgN444 iN2Pw","st_dist_03":"gyN Nw2iNNk gNRRkBBkkBw","st_dist_04":"BNk20LNRik6 yi22RkkkiLRP","st_dist_05":"g R6R44 miN4 wBiB6 iiB","st_dist_06":"PNB6R L6i0RLmNLPB Rkwgww","st_dist_07":"mNgPwmymNPP4gk mLLgLBNP6","st_dist_08":"yyi mw4NRy2L0PR4iNL0BkBk","st_dist_09":"R64NgLRmwmywkLy0wmi6R2 y","st_dist_10":"N60BPmiwwR0LkN 0PyRmi6mB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"k0 6400NRB60BBwmPP0im0mBBB LkNB6k6km4LLNBRNw2g0Pgg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":29,"st_w_id":1,"st_quantity":41,"st_dist_01":"y4kkP 6R w 6L2i Lg NLNyi","st_dist_02":"ykk6kk6Bw64yk66yB LPL0Bg","st_dist_03":"i2gP06wyRNmRiL2N BB002PL","st_dist_04":"NL2iB2ykLyP60ig40gNNNLiw","st_dist_05":"kP24LmRPyBi0w4ikk4 0m 0","st_dist_06":"wkBkP2wR6kL4Nii6Nwy R6iL","st_dist_07":"0 kPRw02B L4wBPNRRPwBL6y","st_dist_08":"RNmmmLPiiwimNwBwNkiiwmPg","st_dist_09":"kRRyNm2RPm0NPNy2mLgN66P6","st_dist_10":"RyiL0wg RBLRy260iwgkk4k6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Nm0yNBm6iyRgRwyi R0kwkPmykPyggLBRRyP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":30,"st_w_id":1,"st_quantity":12,"st_dist_01":"NR6gN6BkkwR PPRkBk0g4g6","st_dist_02":"BB24yLN6Lk2kP6 6Lmy wwm6","st_dist_03":"m02NiNwBy0BmiwNk26w24y2L","st_dist_04":"0ki0y66L4kgw24wLBwi iLBk","st_dist_05":"PmgyyyLP NgBm ywmNyLLg6","st_dist_06":"6gPRiBmLRyw4RmgL0mPi2mPk","st_dist_07":"iy2y6kw wm04BB 0g2yw66w","st_dist_08":"Nw6kP LNR2BwL6PwkR4P0wPk","st_dist_09":"RPkB6ikm6BkPPwBBkg6ggwi","st_dist_10":"kNLRimNBkRBiLkwRk46BByLw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" mN0Py 42B04gmP60PiRPR2mm N2LiPw6g2P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":31,"st_w_id":1,"st_quantity":90,"st_dist_01":"6 NiykB6k N0Lk6Ng giPkky","st_dist_02":"kgyBmP62giw6Pk2Rk6g 6yy6","st_dist_03":"i4NBimP6i2gmNkP L662RBLP","st_dist_04":"R4y w4 Lg0k2RPRB4iw6gmP0","st_dist_05":"6NyP6gRiPN40BB26PP 4L46i","st_dist_06":"NLBPBg2LNPiNRL2mRRk4 ym2","st_dist_07":"6NLg6w6NBPN2iNkkN6P4P6w0","st_dist_08":"iy64B6NkR4 LkP62Ny igBgP","st_dist_09":"iwgm4Pi0Lky4kRyiN2gL6 yR","st_dist_10":"g2gL4wRPmRmL6N22yw4i2Nyg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kww4L0y0R6PPLN LR64yBNL2 P6PiNiyBgLB4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":32,"st_w_id":1,"st_quantity":37,"st_dist_01":"6m4miwk2N646 mgkR PPgk2B","st_dist_02":"w046NBmP6R4PR 26RL6LgPR0","st_dist_03":"yw6k6Pwk2mmigRN4BkRw 6ii","st_dist_04":"iNkw6 0BB66w2ywL4Nk PB6","st_dist_05":"Pimyy2BBN6PgN6PikP40R422","st_dist_06":"LkkkmNmiR2LikBmmNiig0k2P","st_dist_07":" LP6BBBBNNNPPmmwN6R2 w i","st_dist_08":"NwwLg RR240yLm0RwNm L2P","st_dist_09":"yPgRiBL0R2kkLkLikB60P2wP","st_dist_10":"Rk0yRLm0y62mimNPPPi0mRPk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Pmg04ww04mNRgRiNkikkN2 mN2Nywg 0gk44RyyNiBB6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":33,"st_w_id":1,"st_quantity":26,"st_dist_01":"P6R42R0mNmwiP4m0R6m kmR4","st_dist_02":"4g4BP0kL 2NgPyk2ywyP2ky4","st_dist_03":"26yi gRLi Pmm02RkPNLy62L","st_dist_04":"000gwLNP4miLkPii 4N6Rkm4","st_dist_05":"4mRwwRBRmy00NkR2ggy466mg","st_dist_06":"R6m 0Lim i ymLwm2PikwN66","st_dist_07":"wi4PkgiBgPRmkLP40Rgmmwik","st_dist_08":"i 6iRmRmiBL6N26mk4kR0LR","st_dist_09":"B4R46L464L2ykkyR0mk iiN0","st_dist_10":"mg40giy624mRRBN0B Ryi4my","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"y y0m4NwmiikkNLy0mkPwNyy0g Rw2ww 64y44 4L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":34,"st_w_id":1,"st_quantity":27,"st_dist_01":"yR P imRL46PB60R04RBRLw","st_dist_02":"kkRR gRBi4RPmmBPg2 yk0yB","st_dist_03":"6PByBLBw 4LLN2P4wPL4LPym","st_dist_04":"04i PBiL606PyR 4mPi2yyR4","st_dist_05":"44km4m4kyk6kmk gBwgiRP0y","st_dist_06":"wkigL6igP 2 wmw64BRm mN","st_dist_07":"kRi L0LNP64iLNg4 mmPm4PR","st_dist_08":"yigmy6 gy0yBg LmBL m4N02","st_dist_09":"BLBPRPg06gRym642kwgB wPy","st_dist_10":"iiB66BymNmBim4y22miL yRm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2RLgBwww2g06Pk4y0PRLBPLyPyy6Bg6BiywR4m0NB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":35,"st_w_id":1,"st_quantity":37,"st_dist_01":"kNwymRmy6gygg4LBw LRPyB2","st_dist_02":"iPwN kiPB 6i4LgkRm6gN2gi","st_dist_03":"PRL4y26 i2B4w4g4mRNk0miP","st_dist_04":"kNm2NPL6 wB0k4 40kR wiPm","st_dist_05":"2i LkL0mBLPyN00 0 PiPL4w","st_dist_06":"24 m2ggB2NLPNi24gg4BR66w","st_dist_07":"y iwPNBkiyRwB0k k2NygRgg","st_dist_08":"4iPywR iPPwk22yPgyg gm62","st_dist_09":"gN0NikkL2iPNwm L2BikkB40","st_dist_10":"ig6 B6ygBLwN4BPk6LimLiB4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wmm 2kw02gyk4mNPw gBPyywLLRPw"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":36,"st_w_id":1,"st_quantity":53,"st_dist_01":"N4NR0gi0N4Ri2yPwgR2NykLL","st_dist_02":"BLNi 2ywL0w m0giB22mwBP","st_dist_03":"44 RNy6BLBymkmR6wP6wRwNR","st_dist_04":"Pikw04RwBPR Nm6wNwBk2gi2","st_dist_05":"B2kBkLwkkL6L2P04BP06RRg2","st_dist_06":"Pg0 2y604Pwikmk2w2km2662","st_dist_07":"6ky6y46kmR iwLkgRyiL206g","st_dist_08":"gg0gLL0P NN PLLi2022BgLk","st_dist_09":"wkNNmkkgiN 6i62 42kBBmi6","st_dist_10":"kNBR ggy6Biy6w4mmN m 0Pm","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"m60yPwRNy P46RgP66024BLPNk62PPk66LN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":37,"st_w_id":1,"st_quantity":33,"st_dist_01":"yi00giRkwPBNRNw mLRgN 00","st_dist_02":"y PgRPi6Ri460Bi4RLBmk4y","st_dist_03":"NByg0 RLyiwByyyPiw PPPg6","st_dist_04":"N4 y wLm4Ly2Rk6g0g6wLP4","st_dist_05":"4wmRg 6kim L4Ly6LikL60Bg","st_dist_06":"yi4Rwk2gPy40ym2L6ii4mi w","st_dist_07":" wiPP2P yBNRNRPP2Rmk6y","st_dist_08":"k ym4 w4 LgyLB iB4i2gNw","st_dist_09":"Ny40PyL0wyi2 06kLkwkB RL","st_dist_10":"gRkm4kBNky0yRRNwiN2i2 00","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ng00B0LyPmL0y400wyw wmN20PkL2B640N6w4BNR 00g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":38,"st_w_id":1,"st_quantity":26,"st_dist_01":"mRNNy 44B0R4Nm4kN0PBggRy","st_dist_02":"2L4PP4kP mkm0P0L00NmymL","st_dist_03":"0226RiPki6B2B P4yk gki0R","st_dist_04":"Pk NRwNwN6 LL602mg6wRwky","st_dist_05":"L42k66i06i66NNgiyB0wmgN","st_dist_06":"Pi0 B0gywPwgg RB w4Pi46y","st_dist_07":"kLiiwkygBwNRN6yiP600RmRN","st_dist_08":" 06 Ly04y L 6 RPi04yN24L","st_dist_09":"kyy6Lk6mN wN4gwi62 wB0LN","st_dist_10":"BB2R2w 2m4kN wiL2ywwP2y4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NwggLk0BL6Rkm0Pii6PwBLi4g m0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":39,"st_w_id":1,"st_quantity":93,"st_dist_01":"0iyi2w4P4B6gN4kR4kw0wLPk","st_dist_02":"4m24iPLg0mm0R6yggN06RgkB","st_dist_03":"LmgiRwL2 N0R4kmkggg42m 0","st_dist_04":"P62 gi6046km6m 2m2g4m B","st_dist_05":"ki2 wLm mRigBL6mkk6 kgR0","st_dist_06":"46m66 Rg4 w4gRg i4NNygL2","st_dist_07":"g0 iB2PwiNRNw RL64P2Nwwy","st_dist_08":"wB4044RLk2L2kwwk0Nk2NNN","st_dist_09":"immLP66ikLRRN0 mLP2R6R6","st_dist_10":"6PL0442m 024PNPLk4BBBk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"w2iy0mm kByPNk2P4P 04L6y2NggNg4m Bkg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":40,"st_w_id":1,"st_quantity":52,"st_dist_01":"iBNw44kmBPNw4wNR4wB6NiLg","st_dist_02":"yLRLNw0y0N66mw0m6LLiiPL0","st_dist_03":"iyRLP wy40 42mwRm6N0mR0m","st_dist_04":"Lw0g0i6w26P4w4gig4mgRL m","st_dist_05":"4L4mRm6NP6kkNP2kgi N wgk","st_dist_06":"4kmNRPRB4km262gwmB2LL i0","st_dist_07":"Ni6BimmgLwmiNRw0y6Pig2Ri","st_dist_08":"N4BLwykg2kywB2P4B0Bg0B6m","st_dist_09":"4L60w60N0gP2wg0k6RiiR6B","st_dist_10":"ki NR0mBkiLL2iNym4m Liy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NkLkRyBRB26mNL0R2gNyLNi4N2N0kiRLLg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":41,"st_w_id":1,"st_quantity":75,"st_dist_01":"gB N2LR62BN262LkwR4y6gB0","st_dist_02":"2gNBPR4PkiPB06im0wy6iBLi","st_dist_03":"62gm6iyB4w26g6i6gm0666kL","st_dist_04":"4y6imwPPL2kLLR2g2mkRPm46","st_dist_05":"P PPwk BBy4NwiyykkRRBmii","st_dist_06":"y LkPy266 0 NBB0wiNRNR6w","st_dist_07":"BLik 04i6wNkRwR062iwN6P0","st_dist_08":"Ligk0 RNg6wwBB iNiyLPPki","st_dist_09":"k NRik0NL4iNyy2wywRw4N0y","st_dist_10":"2622BRgRkggLwR240RPLyPig","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0R0B0RwNgkRmNiBRNyNPRkk04iP4i2L0k0wkLP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":42,"st_w_id":1,"st_quantity":17,"st_dist_01":" NLB2i62LLmLgNwNmkBk44Lw","st_dist_02":"0w420By2wmgimLRP6 B2g 6R","st_dist_03":"Bg4L 0 6gwNB4Pg0mPmmwwB6","st_dist_04":"kw02PBmkywNiNBwRi k6L0kL","st_dist_05":"mPwi0026wg4g0B NNNNPP0g2","st_dist_06":"Rii6LkLPy6P2L 4g4PRgg 6m","st_dist_07":" BBmyBNB0R mLk0PN mkimPR","st_dist_08":"i060ymNy0yRy N6L2P6Bi2k6","st_dist_09":"0R NRRg4Pm R0BPB4gR6BNLL","st_dist_10":"yk6kwLR40i 2iPgPyPwygykw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"046R BBy NmP6yg2iig 0iL4R4gLP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":43,"st_w_id":1,"st_quantity":37,"st_dist_01":"PLi646NBw0Pg022LmNBy42wP","st_dist_02":"N406B446gL2mgwBPw0RL4gRg","st_dist_03":"B624i2P kmBy4PPRgLywBgg","st_dist_04":"gwkRgNRw20R4Bwgw46 PPig4","st_dist_05":"B2Ly2yi 0BRL6Pm2P RLBiRP","st_dist_06":"iP0Lk0kw4BBPk4m2gP24kg06","st_dist_07":"Pw6iwg L64 yyiyNB4yimi20","st_dist_08":"kmwkyNwiwygygN6yk6PLwL0N","st_dist_09":"iyN gPNg PiPLmmNN0 4wB","st_dist_10":"B0 g PyyRiNiw6wLLmBwL40w","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R20wB 0wBNwwBNNm4Pk6g2iP 2mR 4k2yi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":44,"st_w_id":1,"st_quantity":10,"st_dist_01":"0Bw4PByBBg4PRiwLmwmkPN6P","st_dist_02":"g giRRwRyLiB0PyyBy0y40Bm","st_dist_03":"260PkNmL2w6NwP6R2Lw022L4","st_dist_04":"yNN kNyPgRm2wP4ky wgg6 N","st_dist_05":"iwL LNPNNgRkiR2LLykmLR2w","st_dist_06":" gm0kByk0BP iwRwwygNgkR6","st_dist_07":"wPy4Py BiPRgw6ByNwmkm6NL","st_dist_08":"mym0R6wky2RPkNNm BN6 0Bi","st_dist_09":"iywyk 62RB66wPgB2BP4wPL6","st_dist_10":"wm6NB6iLiNiB4wkLNyyN0ik4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BR6wg2gRBm0wg646L2RN i2L20RL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":45,"st_w_id":1,"st_quantity":84,"st_dist_01":"4RkwPk i0LPB66kymkiN6iNi","st_dist_02":" 2wBgw04RRRkiB040iy026mN","st_dist_03":" PP4RBNPRw26B0y2PBgN24m2","st_dist_04":"wRykP 2k64g40igmkB6gNk0","st_dist_05":"i24666Ri4ymmB 0w6g6Lg0g","st_dist_06":"L40gB gyBNBN66mmRyNL 42N","st_dist_07":"RL2kR4P6442w6w wPk6PPw R","st_dist_08":"wL2Pw4kBw00gB P2LL2R 62","st_dist_09":"2RLiNBg0 Pi2B4i6i6w00gwk","st_dist_10":"RP gg wBB 4R6 P02Rw0iRy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4BwkwR6kPRmy4BPRkRmg4iwi2yRgRyymP2NmiBgPw6LiN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":46,"st_w_id":1,"st_quantity":96,"st_dist_01":"Ni60gm 4y0NP404kRgNBRRmm","st_dist_02":"B06NLP2NiR 00iw6N PiBmwi","st_dist_03":" 00ywy6imiBgyB yL0BRmkR","st_dist_04":"NPy2yBmkyykNkgy20gN02NPB","st_dist_05":"NB44yiBLm2gL gNwRP06m04m","st_dist_06":" gggLwP0gPg i2 R2N k26gm","st_dist_07":"w64kkNiL04BPww2L6NRi 40w","st_dist_08":"Byw6NyP P2g62B mRNwkL6Pk","st_dist_09":"wk6PiiB 44wP6Bw0ygNwBwwi","st_dist_10":"0ggR4RyykPP wRLkgy 2mkg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yRR0mL02NiyR 2 i RmwB2ggm wkwByRR 6ygRmNN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":47,"st_w_id":1,"st_quantity":81,"st_dist_01":"6PRgRmN6200PmmRy0 iwL46i","st_dist_02":" 0k6B6g0N2ikkB0NPLmB2LLN","st_dist_03":"gkRk0RNgLLyRy2N6L4 iBLiB","st_dist_04":"wwP wRyN24NyBBPP62gNgw N","st_dist_05":"NB 4N620wik24 6wL6Rwiw","st_dist_06":"PP2mimyB2Rm 2Rygkmy0iwBk","st_dist_07":"kmN6BNi4mmR PBi24kR0mP4L","st_dist_08":"Bg60 wmwkkyB402kP2 w4y0m","st_dist_09":"w 4BR60NNRNy 0BN04m2m4mL","st_dist_10":"L2 B06NkN6wLwN kPg L04g","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iiPPRPPLPNN B0PgByg2626i0PNw2 wm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":48,"st_w_id":1,"st_quantity":91,"st_dist_01":"wB6gyk06iwkRLBRym66Rkk2m","st_dist_02":"62k4g6BNNBmm0B20i L2y2i2","st_dist_03":"gg0NwBgywB6Pg kBLRNimwkL","st_dist_04":"wNLL46NN0By4kgP0m0w4wLiN","st_dist_05":"m0iN2BR0iy6ygL06P RPPm w","st_dist_06":"NyRyRNPwNkPLy6i0 m kRyL6","st_dist_07":"RyLwRLyyLimRkL4yi2kmL44","st_dist_08":"w04giwy myRLBNkyNm LL6Bk","st_dist_09":"gRm06Ng4Rky0ByRy62ygRmmB","st_dist_10":"026LPg6BiwNLLLNP6PL2gyRP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gyPgyk2gRkgRiy6Bi62 i 6 wBm0P2R Bi6Rg6gmkyLB6g4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":49,"st_w_id":1,"st_quantity":56,"st_dist_01":"P wBw2mwkL0k40PRy4m0g4ym","st_dist_02":"0L4 Rw2k0gPB4gy4gPBiLmm0","st_dist_03":"LLLPN0m6Pw 2gNRy2g266Nim","st_dist_04":" 0kikN6kBBwww2Bgi4ykLPw","st_dist_05":"2RLL0N RB0i2LPRwgRkmP6NR","st_dist_06":"yNm64RRyy02P6w40BPwmLBLw","st_dist_07":"BB22 RBk0m BLBLyBNwmkL60","st_dist_08":"BNL2RkmkgB46LB6RiRPPik g","st_dist_09":"kyP L62iNyyL2mw4Pi kPL4y","st_dist_10":"6BNRBNRmym4k400RR64R 0m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LmkByRmi0iN mymwiPiRk6wkg2mNkRkgwy6mwm4i6PL2P46"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":50,"st_w_id":1,"st_quantity":76,"st_dist_01":"N6Pi6kmBPwyR6imBBm0wkPgi","st_dist_02":"4Ry wRPP6kkRN6 Nw 4LN4k0","st_dist_03":"wP6NmR iyPByy60 gwPig Pk","st_dist_04":"0LNLB64Ly2 m mRgBPP4B00w","st_dist_05":" 20gwyPwR02LPkw26N6w g44","st_dist_06":"R0g62m0LNLmmRPkLLRNB 2gy","st_dist_07":"4yBP6P2Ly PkNw2B kmP00R","st_dist_08":"iR40Rm6PPw0P Nkmk64Ly62","st_dist_09":"BNwim2yBk44P yik4ww60 Ly","st_dist_10":"RLN B4Lim kN migLwN2my6g","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R g LR2w2RyPmR60imRBBg6PB6wywLB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":51,"st_w_id":1,"st_quantity":60,"st_dist_01":"BmBg6BiNyLmLi2Ng4kBR0ww6","st_dist_02":" PmPgwLyk 4mRRPR0 k2NPi","st_dist_03":"iRkyy2Pk 2ig6iPLB2 LRimi","st_dist_04":"Lyk0i 2LNNiiR LP6k LkgyP","st_dist_05":"kBLiL0PPPykmPPPB6NimwP w","st_dist_06":"R4y0NgN0m4m42wR0LwyLLLiy","st_dist_07":"i 0i4mRB6N6ggBy 0L02RRLi","st_dist_08":" yyiw62mw 60RimkyB0mN0iw","st_dist_09":"k4yiPwgBNimg4L42m6yRk44L","st_dist_10":"wLwPRBgRw2NwNP0 iNL0giRP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6RNmRNgNRiy6PPmgkLR BPiNPPN2m2RyL k 4ym4LL04"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":52,"st_w_id":1,"st_quantity":25,"st_dist_01":"g6mPN0PL Liki4BLL60ym0g6","st_dist_02":"NP2L0PyLggkPmwwRPPym62LN","st_dist_03":"02RiL6PmBPL P24gkPk2yN4m","st_dist_04":"ik6RgBgmkP gw0Lm6PR BPm0","st_dist_05":"Bk424BB0wR222 BkmmRL 6gk","st_dist_06":"2462iP6mk w4yLimgBNyPP6R","st_dist_07":"g0BNNiP6i40iiLyNLR4i0mBN","st_dist_08":"ikkgR4046iw04 BgP yNNm6N","st_dist_09":"26N6BRk6LmRB wRm6ii2yBN6","st_dist_10":"R 2kwLLyw2mwykyPLBRP6gkk","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kLN4 0wRwy26Lw0ORIGINAL2ykN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":53,"st_w_id":1,"st_quantity":56,"st_dist_01":"g4NR P2i26 L0Li46m2y Ny6","st_dist_02":"BywPm 6BgNgw4RwkNyByN0wg","st_dist_03":"NLi 6gPi B2gg4w LmBLwiLL","st_dist_04":" wy02wkmyiLB0iNPPL0444m","st_dist_05":"404wiRw0ky0k4Lwy6BiBLyiL","st_dist_06":"4kwggg0RLRP BPgLg2iiPwi2","st_dist_07":"gR6L2RwRP2giy6NimwkNL2R4","st_dist_08":"g m0 ymggmk i LBgPB6 R6N","st_dist_09":"2w0y k4LyRgNg6kwiB4i4042","st_dist_10":"mPg4PLmBi4mw6PBmgRmkkgiR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0y6gR0w2B06 40ByBw2LLPy 06"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":54,"st_w_id":1,"st_quantity":71,"st_dist_01":"y6LRRiww0 B2LB4iNiLPwLi6","st_dist_02":"k i0NgiLigwgR4 NR4k02iR","st_dist_03":"wi060R6ik Lk 0R6Lygigy2P","st_dist_04":"iPB42PkPP6k2Rw4RkP0Nwk44","st_dist_05":"4R0RkwwgNkLw0wRw 2gi0mmR","st_dist_06":" igNR2Piiwi wPyLPRym4NiB","st_dist_07":"y0m66w 0k BPi2wPywgNmkNy","st_dist_08":"g2i kkiL6BNP0B BBywNLygm","st_dist_09":"BLiyR L2wNiwwm0mBP0RN6N","st_dist_10":"Rmy ik6wRmR64 m4yRigyR0P","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2LPwN40y4gmNmNk6w 4m 62NLPwRRkN2BgmL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":55,"st_w_id":1,"st_quantity":63,"st_dist_01":"RBLk Rk 0imPymmk2BPRg04g","st_dist_02":"gm6wyRmPPB0BP6 w R B gg4","st_dist_03":"2g mm L0wLig4P6yNg 4 R4","st_dist_04":"LB 2PPgwB0NR06ig6ykmm2m","st_dist_05":"g2Pg6 0Pm w2B m2g0 Li60","st_dist_06":"4m444RLNkyNkim6L6wRgLBkN","st_dist_07":"k0Pm0P 0k4L2ggB0L 0B60gm","st_dist_08":"0Ly Bw2y6BmwN4m2mBRm20PL","st_dist_09":"4RgBw0w2LgRPk6 LLi64mm R","st_dist_10":"6kLmL6gimy064226yyw6P y4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6iN wk6mP0NNR66 B2mB 4N gBwPgBP LB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":56,"st_w_id":1,"st_quantity":28,"st_dist_01":"ywBmL0k 24k6yRk026kkw0Py","st_dist_02":"P6L2ByN0y iiL0B Rw6RP2gg","st_dist_03":"gN0yi2kwPwLm0BPL2kB2w202","st_dist_04":"4P4RL6NNBwRR0BywLk4Pi0yP","st_dist_05":"g0626PBBk2ykNLi2iyyiiP46","st_dist_06":"P 6mPm P220myi440N0yPRBy","st_dist_07":"yy 6kyiw2Bww4Bi 2kBm2k4L","st_dist_08":"26gwmBPm6ii426P0y 0PNiRR","st_dist_09":"LNRyBmR0yR46 N6Pwmw wm62","st_dist_10":"6gyR6wk2y4gL042RPRwyi06m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ny6kRy6BNky yw6RiRw0i2L204B40gw2m42m NRi4ww"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":57,"st_w_id":1,"st_quantity":36,"st_dist_01":"kwykP64yLL64R0 B6R0 4yPL","st_dist_02":"2yiy2L6k4RLBNk4Nw4Pw6LBi","st_dist_03":"0PBwRy gLwPmy4242 RPiRy6","st_dist_04":"0Nw6yy 6gkmRyPiNPg L iBm","st_dist_05":"4mBm02R2LB0 mPN mwLP6Bm2","st_dist_06":"mRgwmRyk4BgwN L4iP BBy4g","st_dist_07":"LkRkiN42yiL4iBw6gk4iN RN","st_dist_08":"6 PL0Nmkwk0L gRNRL2Ry0R4","st_dist_09":"LywyP4m6RgLgP LPRgLmBN4g","st_dist_10":"Rmw0R BwR0ikm B i4m NNPw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" NkL404BB 2g6L 4RPLiw g04ORIGINALk20g iiLki26L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":58,"st_w_id":1,"st_quantity":54,"st_dist_01":"Rk4wPiykmN26BRPy2L46Nk4y","st_dist_02":"m06Ly2wPgg 2NR4R2BL gPL2","st_dist_03":"i0640kBy0m4PNBkgw4i B6Ly","st_dist_04":"RBgP 0BP2Lmm6m0LNk22 iR0","st_dist_05":" R w4kgwRkRBR 0R 22L60iN","st_dist_06":"N kgiwPB kwmNmw2mBP Bkmm","st_dist_07":"kmmBmLgmmB6B6wBgBmk m 0N","st_dist_08":"gPLB26B RyPyBw00kk42RgiB","st_dist_09":"kPLmyiPwN4iLyy40giky2LLB","st_dist_10":"gLyRR2yNBgBPRy042224 6N2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"P0N2P2gRNBmR4 64BmR4iNR02g2BBywkR2w02Ri2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":59,"st_w_id":1,"st_quantity":13,"st_dist_01":"6 4P 0NN6yRkBB mm60BwyB0","st_dist_02":"m06By6NRyRimPBmiN24myg0k","st_dist_03":"kkPyyPPRg ikNLgi6yB2ygmw","st_dist_04":"Ng6PPRN2Rkkm6 m2B2kmwwB4","st_dist_05":"gmNkN4mgkmwy2 P02B2 w Nw","st_dist_06":"NLL22B4 mkN0iwP2 RmB2PB","st_dist_07":"wN Pmy0kRgRww0ykwyNRB4mg","st_dist_08":"N0wi06LgN0y 6LP4N2Rg6i2P","st_dist_09":"0kPL6B2 miP4g 4kkNgBBmy2","st_dist_10":"ywP2PB y4yNm6imN4L20RyP6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0P0R6wi imL iLi26k0404kwyw2m0igkBP 0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":60,"st_w_id":1,"st_quantity":37,"st_dist_01":"iN4wLP2g6ii00i0iwkPiwiLR","st_dist_02":"BiRNikNP6yRyg4PNP0gikk06","st_dist_03":"wgikBP2BLmy6BL4i0LwPmyL4","st_dist_04":"mBw6Bk 6RN 2624 B040442B","st_dist_05":"04Rk Ng44Lmi2L2Bik06L4mP","st_dist_06":"ywyNB2yP2N i0PRPw LR4iy4","st_dist_07":"N k6yLBw4RLmkyRNLmi0Piki","st_dist_08":"m00L264i yL6RgiNgR44PmyN","st_dist_09":"LPNmywy4w6NgLwPPB4wwyB4B","st_dist_10":"P60NLL6RP66 L iPL iL6NBP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g42NyRm2LLN4BkmkP P2iwkN0Lgg4mLkNy mgNPii26wmw0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":61,"st_w_id":1,"st_quantity":71,"st_dist_01":"BygPk4PNm2Li44mmmkiLLN6w","st_dist_02":"04gm0Lg240ygkP6wPw66mRiP","st_dist_03":"4 mm66RR R42RN P w6P L44","st_dist_04":"gNm6gPB2 PP46NwRyNPy642g","st_dist_05":"RmRy6PNBwykBk0Ng6NkR2B4w","st_dist_06":"RRB0LgP64P40i6mygg6204 N","st_dist_07":"NyBNkLkRRBBg0N kRywRLmyP","st_dist_08":"4kP6yyLm60gmkN0ygN0iPw k","st_dist_09":"L0 wgkR2k24L4 R kwPm mgk","st_dist_10":"yk6NmkiNPg6iPBy mmkPgwyB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NyR4P0B4R2Bi0 4iNPyRR2mw6 wNRRyk06gk00m"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":62,"st_w_id":1,"st_quantity":32,"st_dist_01":"gyi6Ri4BPwP6gPNi0RggPR02","st_dist_02":"B0N6y 6N0yg0By2giw62ikmw","st_dist_03":"BgR6RLRkmP4k62R4yw640Lyw","st_dist_04":"26wwyRmBPi6RLg60wm2PPN46","st_dist_05":" BykLy6mN4igRywggLyPP2R0","st_dist_06":"BmiR 4iwwikyNPL4mBR66PB","st_dist_07":"R0246426220i Rw gmiwyg4","st_dist_08":"i6yi0 Pigk4P2m02BLikLwyg","st_dist_09":"N6L gm4L R04i4wgLLm0m602","st_dist_10":"0NNPgwki20BB2gRRB ykiim2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" Ny0miRkmy2Rgmw424 gyPP6y2P2kg2k406"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":63,"st_w_id":1,"st_quantity":50,"st_dist_01":"k4Bwgg PgwgmL2wm6R0mi2im","st_dist_02":"4i04kkkR24L0wy B2yRPy6N","st_dist_03":"w0gPL2w6mPmw04LgN2 ikmgi","st_dist_04":"L4Bg yBmi0RikRwPgL2N0L 2","st_dist_05":"22i4mL2m0L2B L66ki02wiNg","st_dist_06":"i26gR4L24yLi4B R0Liwk yB","st_dist_07":"RyLNkNR2y0 w6m BRLmyi2ik","st_dist_08":"gPg PN44Pmym26kB4B6NPNR2","st_dist_09":"Rmm2wBPPkRk6kiR2PwPmwgPB","st_dist_10":"Nmm26BLkPL2igwyimNNLy4m0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" NP w2w0yLyi2BBww6PB2R6Ryk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":64,"st_w_id":1,"st_quantity":24,"st_dist_01":"ym6Lkgy44g46 06w R Pg6Bk","st_dist_02":"m0BwBi6y4Rg04Rik4NRi4RyR","st_dist_03":"6gBy200 P600ggB46mL4NkiL","st_dist_04":"4ggPg R4PL0y6ymmmRPB2NR0","st_dist_05":"R6y 2k66km44P2mRmy6g Bkw","st_dist_06":"NyimgwwyyPP P PPR4R2igkg","st_dist_07":"26 BkN46BB44L2Rm4NNNR6wP","st_dist_08":"2iRk622mmR N66P0NNBNmLPw","st_dist_09":"0L4k444R2Bg4yLmNy0y2P2 k","st_dist_10":"mPg4N60PPmPgLL6PRi2Ry4i4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6ikkggNPg0k04gB BwmgmgyBmwwy2B6Pyim0P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":65,"st_w_id":1,"st_quantity":45,"st_dist_01":"mNw2y6ymR0w02P426wkPii4g","st_dist_02":"iPN6RiP04i62Rg6gRiLPi0RN","st_dist_03":" my RBPLRLNgywk4yk46gkm0","st_dist_04":"PLmP0gyLyikL2L0iBkgm4wmg","st_dist_05":"R 0424mL0N6L6ywLigmPw6NP","st_dist_06":"ig Lwwi0iBw04gRNNg 4P 6","st_dist_07":"Rm0BLimLiNB0BR00 PR6Rki","st_dist_08":"y0wm6yy4m4B6wm6RNRBLRwL2","st_dist_09":"0i0iw L4PmNLww0P0y2 w6LP","st_dist_10":"L4 000iyPBgLwLgkgLP6mP64","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0 66gikkPkm iyNBNLmLLB6B4kgwkm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081214,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":66,"st_w_id":1,"st_quantity":15,"st_dist_01":"Pyi 4 Piigyg Lkkym02gLN2","st_dist_02":"Lyk w2mLBLNyR 2 BgNm kg4","st_dist_03":"kw2ywyBR660kN6NNBw24ky0B","st_dist_04":"2wmkiP4LBwPLkw6g N0wN0my","st_dist_05":"yimmwyw0 0R466RBmmm6Niyy","st_dist_06":"L2gPNNw6wN44Rg Bk4y2gLBL","st_dist_07":"NBL4y0 PRBgLwwR4BR4k2BB0","st_dist_08":"wL4L2imgggmRwm0LkL406NLP","st_dist_09":"iwyi00 42 g4kwky2ywR2yN","st_dist_10":"y ig22Rwy 2NLiR04y6w2N4B","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R2 0wiggikg604gRky02gmgRBLmRNi202P"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081214,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":67,"st_w_id":1,"st_quantity":50,"st_dist_01":"i k4kg0R6kg2Lw6yB22Pk4BP","st_dist_02":"PN NgR6260gP4 LRiPL4kmmi","st_dist_03":"00mmPR2mygmkwB2L2gP42gyR","st_dist_04":"40PL0BkN66kmi4wR4L6620RB","st_dist_05":"6i Lkg26yL622Rww0PN Lm20","st_dist_06":"m2yBmiiRBw666 yLN4i0PNy4","st_dist_07":"Nk2mk4yNPy20 w6ig62LRNkg","st_dist_08":"BPm0NmP 6Pg4iB4w2LL yw24","st_dist_09":"6N4k0y2gi00g6N2ig2 6BL00","st_dist_10":"wmmyByRggiwRB6 w4wPR kP4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ii62yBR wiBkPBwmi4y24iyiLkN2mwNmyi0yR4Py6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":68,"st_w_id":1,"st_quantity":30,"st_dist_01":"6y2LykR204gmmLy0PiPi00iR","st_dist_02":"2kmgNB wNLN6R4BP0Ly 0NRB","st_dist_03":"k40iB4g B466 Rig60 ygmwk","st_dist_04":" PiwNyw6wN 40NNLkN6L 00y","st_dist_05":"iygkg0 iyk6k4wBmmi kN4m6","st_dist_06":"gRLB24yB0wBi60BPL02NPmmi","st_dist_07":"iNm R 4 m4yg60NL6yyL20gL","st_dist_08":"LL PLLkkymkwgN4BL4y2BwiP","st_dist_09":"g04N yggLm0NkNR6ygkiy26w","st_dist_10":"B4wPPLyw6mL 0m6y20Pg6 mR","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BBw06kyL22462g604LwR ORIGINAL44iB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":69,"st_w_id":1,"st_quantity":46,"st_dist_01":"400N mgNN6NRk yP6k0y6i4k","st_dist_02":"4N k6420 ywim0R0P6RLR60R","st_dist_03":"NBR g6kBR0mLR6kRgPgi4RiN","st_dist_04":"4RRgNk iP6wBw2Pw k B40LN","st_dist_05":"NLw22R wg6P6mPwmLBPmg2kP","st_dist_06":"gk 4w m4P6N0B646Nw06Bwii","st_dist_07":"gyiPBBmB L2Rg6BN6k R 466","st_dist_08":"B4k44ymwwiL0gLygwNP42mw2","st_dist_09":" w4iNy4yyB2 yNRBy6LyN k","st_dist_10":"iPLPLw0Nyk0LPBRgLNyPm ki","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":" R4P 22k20imgkg0 BRR0m4mmP6NPPLyiig22iORIGINALgP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":70,"st_w_id":1,"st_quantity":99,"st_dist_01":"R kB4gkk04RNBL6y0Pg4wm i","st_dist_02":"N2y2kRBm 6kiNgB 0kB22wk","st_dist_03":"gw6yPi0P04RLRgPky62N2gRB","st_dist_04":" RgmB4gw00PR4gP4RN22m0 L","st_dist_05":"LPBRg0LP2gy6y6PgPm RNRmi","st_dist_06":"P 06gk4kNk kLyPR60RyyiRk","st_dist_07":"NPg2Lw2RB2 RByPyL2 kR4wN","st_dist_08":"iR2iLy4wPP2iLkL2 0Nm ymg","st_dist_09":"yB44L0RBgPik6ygwgmwg0y N","st_dist_10":"m 40y02R262ikLgB B44Bw0m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2mLmP2g0PmLwmiPR66kmgw4y4wPNgR66 kL2mg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":71,"st_w_id":1,"st_quantity":72,"st_dist_01":"wP4NLNggmLRikN4Lwwy4kgi6","st_dist_02":"RNmN2mNy2g6Ngm4wPwNgiiBy","st_dist_03":"kmiP0mg606iB4y LP0m N6m6","st_dist_04":"yg w PR g06NNRggRmLPN yy","st_dist_05":"LkgL0 wi24NgmR2LBymNNg4w","st_dist_06":"NPwi26 iy6mk mwPRyk22N0B","st_dist_07":" yL6kgiyNgy0iN yk642i wk","st_dist_08":"6402g2gP6NBg6B642myw64Ni","st_dist_09":"mwiB mRP0B64k4wk ykg2kgN","st_dist_10":"m2NLL4iyPk LBN46N26LB Py","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"0gi2L0i4kyBNP2BkPgPBN02igig22kPg0 iiR0BB40 20g0wk0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":72,"st_w_id":1,"st_quantity":85,"st_dist_01":"6 k4iL4RL404 ygg0gw4NgkP","st_dist_02":" Ni0Ngk6Lgm4wkN 0Rg iw N","st_dist_03":"Pgk0Bk6kkRy242k0RmRwBNP0","st_dist_04":"gggg RkygPN2P0k0 4Bkkywm","st_dist_05":"m wPg6mNgPywwPgy RL06iyP","st_dist_06":"B6mN6 mik4y0Pyky0k0NiNPw","st_dist_07":"2ik0k BNwygmw4ykLw Bii6","st_dist_08":" L2mPPB0y0k 6P6my 604 mP","st_dist_09":"myLg6Nm 602 mkw64Pm0yg26","st_dist_10":"yLm6wNwwyy4PNwNP0 Pkk40N","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"g2mPmBk24N66i0wkNm R62y4P2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":73,"st_w_id":1,"st_quantity":86,"st_dist_01":"igPL042Rymmkm26y4wRiB2L2","st_dist_02":"2wPPwRkkwwm6gkymLL2wyP g","st_dist_03":"wNm4m66ggm2RmgmB 22wBgRy","st_dist_04":"6kyiNPg4Lg2k4Nm0mBRNPwNw","st_dist_05":"gN6PgP4k44gP4yiyNi kP PR","st_dist_06":"4 0Pg BwL4L40mRkPi6gBkL","st_dist_07":" 2m LmLP6B02B6BLy6LPkB","st_dist_08":"PLwR6PBk4BPBimigk 4kgR4w","st_dist_09":" BL46ykkRmm2N2BR6m424mmw","st_dist_10":" BLmwi4kk Ny2myP2Lggg2g6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wy40w 0PBB BLyw2PN6Bm4Bw0my4 6RgiiR2460PPBPy2"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":74,"st_w_id":1,"st_quantity":35,"st_dist_01":"4NLyyymk kNw04Ly0N0gy2mw","st_dist_02":"Pw0mBg 40260Bi6wi L6PBig","st_dist_03":"i6k24k06RRm 6wRwwR0 0y0","st_dist_04":"4kP4 NikRwg0mB264mkRmm6B","st_dist_05":"BN4kwPPgP2LNw42ymk k0mm","st_dist_06":"NBm0wmNRLkBggi wL4wPmwi0","st_dist_07":"RByRRmRy4LByPw6gggRg0Pim","st_dist_08":"4N22w06mkL2wP02R02N kBRP","st_dist_09":"i 4yLwN6Bg0yRmwimw NgNm2","st_dist_10":"0g0 0Ng LNw44i02LyggmLN","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R4P62iP k6ymgwORIGINALwkNw6420PwPk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":75,"st_w_id":1,"st_quantity":37,"st_dist_01":" 4BwPkw4yy2BNRgy4 wkB6i4","st_dist_02":"BmRB0Rgm 6i4R2N2ik4gi4ky","st_dist_03":"wR6wB2B4B4N0NLR ym0L4RBB","st_dist_04":"k6mPNmmPLNwmPy4wLwR k mg","st_dist_05":"60BBw k22 2N2yBwywNy2m","st_dist_06":"B60kwNRyyw RLB26myR44L B","st_dist_07":" Byykg yiyk6gwwRPB02B6w","st_dist_08":"ww4 iRmgyLwmwP BmgkLgBiw","st_dist_09":"Rymiy6iw 6206BkRgkBNBPmw","st_dist_10":"40ywm NwgPRwLig0wNyBgm2k","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"RmLg4 Nkm6B24LBRkL0gg2B Pw BkL wPgRP 0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":76,"st_w_id":1,"st_quantity":76,"st_dist_01":"wRyRPy4iNmmRRLymkBiB64Bk","st_dist_02":"206yikN4g2Ri6g6P4mPLkBw2","st_dist_03":"0 gy46iNgwk64mLBBiggRkik","st_dist_04":"PiNgiiiB ygNwygyi2yi 6 2","st_dist_05":" iw 4L46gygwiLRgPymm6 L4","st_dist_06":"4k N40ii0mimwNBB0mL4mBki","st_dist_07":"06mmB4yLRPPm02g2ikNPiyP","st_dist_08":"0PB42iwiw6k2kL Nmiky26m4","st_dist_09":" k0yP0kkLg62NwkgN4iiNB m","st_dist_10":"24 mBkNwRkyPL6LkyyRki2R2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"k0L 0yi4BLL0kg0mwLBk iwg24LyyN2k4y2i46i"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":77,"st_w_id":1,"st_quantity":57,"st_dist_01":"64g LP NL6RiP4406LLg 4L4","st_dist_02":"L6022LmP4wN646LRLwL04LLk","st_dist_03":"P6k2Bk2B664gN 4LPkiRBL4y","st_dist_04":"0ggP20BRRkRymN 2R2y6NRP","st_dist_05":"P6yiiyymR0NN6iy4wNm0iP2B","st_dist_06":"wiP4kwi4PLgyg2RP06wNmmm","st_dist_07":"0Pgmwk64 igPP02yw46 L4y","st_dist_08":"6gB2PNNwmNmR2Nigy0LiPii","st_dist_09":"0ykiwk6wB RRmNmkw2PBgNBm","st_dist_10":"LwP6PBLy06B0m0w 4Liiyigi","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"02gLi4mLw06wi kkgR0N kBPPPRL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":78,"st_w_id":1,"st_quantity":90,"st_dist_01":" y4Bg2LP666 62mPPk4NRLL","st_dist_02":"wiy42Nm4w6NPkmBgmBmPyBiP","st_dist_03":"kLww2LwkLR0kgNmgPi0N2L62","st_dist_04":"6g kmkRLyBmL0iR iP2L42BR","st_dist_05":"gL44w6LPyiNk4L0yL6gikPBL","st_dist_06":"kNmBy2 6gywNLNmkRi2iy2R2","st_dist_07":"wg NN0wm imN6wiwmBPw4g0","st_dist_08":"60m4mgg6wii4BmR6Pkmw PPi","st_dist_09":"R2BNiBNB Py62kLmkymR Lg2","st_dist_10":"w0gNyL 6kR 6gBPwR2yRBB 4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"Ri0L6 6m46wLN6i4Ri y226wNiLg62R2kLiPgLiBy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":79,"st_w_id":1,"st_quantity":79,"st_dist_01":"mk4w gRRkP06mmg2NiRm 0Ly","st_dist_02":"2i2g0wNkB2Lgi0262BNLgwi0","st_dist_03":"R2PBwiBN4Py6BBLRRi6 0wLk","st_dist_04":"4LR2k2NwgmLRggBgBLkL6Pgi","st_dist_05":" BwgR44L06PRP6NgmRmL26g","st_dist_06":"62NmkB0y yB4iPB4wRgR0m2i","st_dist_07":"kNkw4wBBwBwgNikLgRwkg gm","st_dist_08":"i PL0iwNwggy2 mwmyRRm6g","st_dist_09":"Nw0k6i2P4PNi0kLmBP2g 0B0","st_dist_10":"46wgg06g40Lyg602kPyyP2LP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R4gi 20B6ikRgiyi4PyLLwLmyNBBg2ORIGINALm2L"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":80,"st_w_id":1,"st_quantity":22,"st_dist_01":"62iBwLBPkwiL62kP4iBwBkyw","st_dist_02":"m066Pmii wBgwimw20B6R 0P","st_dist_03":"iwg2gg224B2RwLm0 kB4mgPP","st_dist_04":"B42B4N6RyBwLy6RwmygBP km","st_dist_05":"kww0BBi0LRkBLiL2 k46R0w","st_dist_06":"mNkNNLmykikkwyiiBgky2Nwm","st_dist_07":"i LNm RmykiLB4y226N4mkR","st_dist_08":"myR4L2gg y2RwyiP2L2w4Bgk","st_dist_09":"26gB6w mL26mByLy0gwyymLi","st_dist_10":"4Ngy6N46 0wBLNy6iRPm40g4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"i66LgmR2NP2Rw424kBgR46P200L4NLkB6NLBiL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":81,"st_w_id":1,"st_quantity":92,"st_dist_01":"Lkg6 gPgyykL2ik6BPmgRL2g","st_dist_02":"i42gPPik2yyRBy6L26kkiN 4","st_dist_03":"4R B0ym02y2BP2LgwByiR60B","st_dist_04":"yL2PLy220wPRmLwyRykN 4Pw","st_dist_05":"B2By6wgyBBiPgBBN 2P4L4mw","st_dist_06":"R0L4k P4R4NRBmiwiLRP gBw","st_dist_07":"0i6mm64BmRNmBw60ik2gL6 4","st_dist_08":"gk4 0 604L PN4Rgk0iNmm4","st_dist_09":"R6 ki2ww6 ww NNmRL26kgNw","st_dist_10":" 64ymRP4BPw LwRNm4RPN4P","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kORIGINALB4iyw262ikkBgRBwPwkNkLLikyRP66i6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":82,"st_w_id":1,"st_quantity":57,"st_dist_01":"R0Nkmyg0gk6wgmyLmmyB Bgg","st_dist_02":"iP0L4wmB2PR0 R 066P44L","st_dist_03":"660Pi0i4Pmi4 N2y4iRwk6 B","st_dist_04":"RN6mw4ygigwiyNB64i20gkBk","st_dist_05":"4k4i2P2N4ikymP 6mm2LRRmm","st_dist_06":"RiLBBRyBy2Ryk46wm2kB2iPi","st_dist_07":"ggiPL4m460R26L044LigkmB2","st_dist_08":"P2wkg0 2RBmPBmgm2RBki mP","st_dist_09":"gy BBgmiwiki44 N6PP0yykg","st_dist_10":"0P2mw06Pkm24PNRiwwikkym4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LgNLmk46Bmg2iN0P0B N4R40imw664gy0i64Pgmy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":83,"st_w_id":1,"st_quantity":59,"st_dist_01":"iBLL0N0B620Py2iL 44RPywy","st_dist_02":"R64gmP04PygPP0N04w4gBLBi","st_dist_03":"Pk Pki0k2gRyi2ygNBRwyk42","st_dist_04":"2i0k00RPggPg6 y24LR2BiRk","st_dist_05":"gwmNRw0iPRPR4wN02R0PLRi0","st_dist_06":"2wPg4PBiwRBwk0 gkLgRywNN","st_dist_07":"LwN4w2yBNmi2B0mwyP20PmB2","st_dist_08":"Pm2By2ky6N0yiP22iNNmL g6","st_dist_09":"kL6mm2yNN2kywiNkRB6w2wg2","st_dist_10":"NPkPL Lww6Nk4R6wmk g4yRP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mgg NgB64 w06BP6gBRNL2RR4iNiymgBL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":84,"st_w_id":1,"st_quantity":58,"st_dist_01":"02LwiR4y4RBBiL6Pg2026 BL","st_dist_02":"kmm R4giPRN BkLPR0mNPywm","st_dist_03":"BBPg0yy4gL4g4LgNwLNRkiL","st_dist_04":"P2PBk20N kiBL6Nwwwi426R6","st_dist_05":"my02N yimP wkyL w0NL 2gk","st_dist_06":"Rwy62PR66mkwyBLPky2ikw4y","st_dist_07":"k6R 4R44k02kkwNBkkk2P2yL","st_dist_08":"LwwkmNBg 6gLkyNigkL kiBw","st_dist_09":"g0 BLyL2y0yNyP4iN gmig02","st_dist_10":"kikgymNRLkkPNy600kiBPPmg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kNmPN2P2 i2i0LRgyiggkiNN 24kgg"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":85,"st_w_id":1,"st_quantity":71,"st_dist_01":"40iN6NB0Bi mw4P6P R2y4mB","st_dist_02":"wLkRP4kByBw0PgPww6kwPyRg","st_dist_03":"yB6gBygkwP4g kk6y6gNLiPN","st_dist_04":"i0RPm6By B6gwRk42LyN42g4","st_dist_05":"6yR4BR L2BNN462w0kL Pw","st_dist_06":"4PRk6m226R02g6Pwg06P4L0w","st_dist_07":"RL0wByR0Ny i6km0k4k4Rg26","st_dist_08":"wP6kLNBL6gPk2Lw2i6BNNN4g","st_dist_09":"62R6iBLy2BLyi 64B262NgRi","st_dist_10":"0RgB60g262mRNLywwPwmRLLL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"2B mRN wB0LgRNLBPy006PPimL 0mk44wygBkwLR0B0mNyLk"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":86,"st_w_id":1,"st_quantity":69,"st_dist_01":"RwR6BBk0 NLggy4iw00gNPRy","st_dist_02":"PRiN2LN 6BkkwBwBRwPNB4gP","st_dist_03":"6R20NLLBPiB6yBPLg6 0kNB","st_dist_04":"yyw4BRm04 kgBB426Nw 6mLR","st_dist_05":"6 Pg g m20gRLN PyNLy26gL","st_dist_06":" m 6Rm6w 2yk2wL42kP62N6i","st_dist_07":"N4 mB6i4wm6PBPmP6iky6kL2","st_dist_08":"R62P4ykBB2N 4 wmRP w42m2","st_dist_09":"0RR64BR 2R04gRRLLNR20mmw","st_dist_10":"mgmLkwiNwRm2myk42R0P0PRB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BRP0wL00 2NB P Bmm4mg LPi0Nw2i046iL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":87,"st_w_id":1,"st_quantity":18,"st_dist_01":"gy44y0 64y yBR0N4P6B mm0","st_dist_02":"NL gB6 m wwiRLy2NwL4NR2B","st_dist_03":"gkyPyPNy 6w2wN4RmPLLPyRN","st_dist_04":"g4gP 0406LiLLik40NN60kwg","st_dist_05":" 2gBgwiRPyyPg6yB0kk06 k","st_dist_06":"LmRN0 iwP64B0 Ng2i2PPgyP","st_dist_07":" g2PB0RLi46P6k0 N2B4BiiP","st_dist_08":"06iyy4w0 m6iR6k200RmLwi4","st_dist_09":"N002BBy2 ygR0R2wm2LBLPk0","st_dist_10":"L4y4wkk04mmN6N4LNBPwP N2","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"ki6k4RPkykNB6wyyORIGINALPBi6 L0RNNmm4R46kw0"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":88,"st_w_id":1,"st_quantity":32,"st_dist_01":"P66R0kR20Rwi2wm0L4mmRg0R","st_dist_02":"2i4yBi2LyRwNywkik m PN6y","st_dist_03":"iwBgmyRN 06226mR42w6yPww","st_dist_04":"mwwmRPPyRm4LPB6iP6Pm4LLi","st_dist_05":"L L6B24Ngw wimNLNwyR 06y","st_dist_06":"NLNmi22LNk0 2iPN0NmP4L2i","st_dist_07":"4Ni4gmmmg400Bii64NPLiiyy","st_dist_08":"Riw iP4RPR00Lw mP RkwwgR","st_dist_09":"Pw6mmw2NwkyBiR imL6P2 Lw","st_dist_10":"26iy24L4 BNP RN64P0wyBB","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"NwkP0gORIGINALB2kw0wNL6LBLiNgkggw2P6k6kRmwi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":89,"st_w_id":1,"st_quantity":71,"st_dist_01":"4yRgi2i4446446mNmNgRmm06","st_dist_02":"PgNi6 NL 2w6k4iN2wRPP64B","st_dist_03":"6LkwiPR6kyRRPwPyLkgPN2wR","st_dist_04":"LP2kBBwm26kiw mBN0iLN62y","st_dist_05":"N46miR0ik iLRNm6wgmRw6k6","st_dist_06":"46wBBmR2Lw g2ik04i4wBNLk","st_dist_07":" 62yRi2 L2LywwBBg0wPy2B2","st_dist_08":"wm4i6 600NyB0224gRRwNyg6","st_dist_09":"PN0 k2ymBk0gi2NL R6mw6B","st_dist_10":"6 2P44 2gB mRkkR04Ngkgkw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gyLNBiBBi Li Lgw2 BB6By4 P0kBBmy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":90,"st_w_id":1,"st_quantity":61,"st_dist_01":"i0w6kN2BRmk NN4k040NB244","st_dist_02":"6P mBgggiR0kL4kgmRmg0BLw","st_dist_03":"Lg mm0gP0kw0BNm0wRP0iPB6","st_dist_04":" y4kBB42k 0PiNi6k4Bwyi0B","st_dist_05":"B Pw2B4mRBRymigyR iN0k2","st_dist_06":"46kkyLR0L6PRmN2LiNm0RNmw","st_dist_07":"m 20BmLBB0L6NyRwgL0 L0yL","st_dist_08":"24NByPiRkiwP y6LyiNPB462","st_dist_09":"BPNgm2k6NR64N2mP64PBPgNR","st_dist_10":"PkkLigwBgN2kP0RmN6kBNNg6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kgwg4PiPwymi2N 04 L004iwL0wyB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":91,"st_w_id":1,"st_quantity":32,"st_dist_01":"PBLwmw6m2ky4LNii2L 6LyP0","st_dist_02":"6B0ymw2ww466Byiiy0kk6R2N","st_dist_03":"022BBNiNR 0yim 0BPNkRg6y","st_dist_04":"2 kgLRN BwgPyNLiimkkykLi","st_dist_05":"LiP06 N40NmBBR6B20RiyLwg","st_dist_06":"km4yRNm2gRwkLgmk6 Rmy4w6","st_dist_07":" 2mLg24m4BkRyPmR0wy Ngw","st_dist_08":"g4mk6y0B2iPwmmgP4igRBgwR","st_dist_09":"Bw0BPB4NB2wk46B w6R42 46","st_dist_10":"BLBig6Byw4B4RkP6N6L2kRgL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"kwyLNLg L R4B2BPii4mB0wi24yg 2BwiORIGINAL6"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":92,"st_w_id":1,"st_quantity":27,"st_dist_01":"NPRwNR0iPNw iBw 2240L420","st_dist_02":"wRgmkB6mByRky4ii2L2RPP N","st_dist_03":"2m4L0226R0 gNL4k002BBmL4","st_dist_04":"iR BPN0L N6R6igP042B6imy","st_dist_05":"04kgNBiN422m6imNmLi2 Bg4","st_dist_06":"kPkmm6iBmmg4mPkywL2y Lg0","st_dist_07":"w42kNy BigRNkyy2miwiNNRy","st_dist_08":"myP6kP22 mLP6N B02R6y26g","st_dist_09":"kk2BPykyykmgggRBmik2w0Nm","st_dist_10":" PgBRR4 gBmk2 6NP kwwy4R","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"P2 Liw6mR246k4LB06g4yPBBPgkyP BP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":93,"st_w_id":1,"st_quantity":79,"st_dist_01":"R0P4wRN LL0RyNwyRmy6R2 m","st_dist_02":"2Lgw44R4img4LgRNLgP0ywLP","st_dist_03":"L2 0R2BN222kgL64NygLy4 P","st_dist_04":"wNgNwy60N6y0mk6RLymwiigN","st_dist_05":"m0iRm2mLikN26PP BgmgLiNk","st_dist_06":"Lww6w0mw2gm22gmP46Pw22R4","st_dist_07":"PP6PBy2N0 NgiLwi 2mkPwNw","st_dist_08":"L RRP4iwimiimgB Rg4w4ww4","st_dist_09":"w6wi0ym2L0RRBLyyNLmgLNkN","st_dist_10":"i2B6BR4wyBN6NkkPgy6 B4B0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yRwL4220R0yRL4 m0mgwwNw24PN4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":94,"st_w_id":1,"st_quantity":52,"st_dist_01":"6BB yL R4iyk64P0NP260R46","st_dist_02":"g0gRNPRB0y6g4yg Bg2mwygP","st_dist_03":"RRyB2i664ggL6m2LkBRN2LB4","st_dist_04":"4R2wwN0kmg2L2wB6By60BNLN","st_dist_05":"km6RR2mwLLPg2P206LyB wyB","st_dist_06":"2mBL6mB4N iw4yk2BP4ggwB0","st_dist_07":"46mLgmgiN2i2P k2mkw0g6wy","st_dist_08":"N2L4w6yPRkP 2RkiN6mLB0LL","st_dist_09":"yNy k6w4ywim2wBL6BLiNPP6","st_dist_10":" 6mRP6R4w2Pk4gg0LyLLyR0L","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"wiLLRm2B0Pi6ww y6L wB42NPNRR4 2gg0kL4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":95,"st_w_id":1,"st_quantity":15,"st_dist_01":"kg2LRNP0wiLPg2iNBPwB6k4N","st_dist_02":"kiRy6P6 m446Pywmk24g6g w","st_dist_03":"64yLm6 kNmgBPPwkR2m6y2iB","st_dist_04":"gL 6NR6kRkk 42B40gRwBi2k","st_dist_05":" 0g NPRB0kB2wkgLm6yg4LPN","st_dist_06":"2L2Ri24NR6NB4N2BB6NB4 6B","st_dist_07":"g B4R620w6 y4N0Ni4L6Lyg","st_dist_08":"L22L002RL42RgmR2L2B4iwLN","st_dist_09":"06 iN6RN0giL6LBL4BmPiPkk","st_dist_10":"LkBB0PNB6wy 4PBB 2PwigNL","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"m4RP2RN2R0iN4264kNNwwPPLgLi4iB4L6w2 yN0gyLw4P4 g"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":96,"st_w_id":1,"st_quantity":50,"st_dist_01":"RLiyyLBkwB igL g4kLPR2y","st_dist_02":" 0m0LmNk4yLiB264L P0yN0","st_dist_03":"RNRk4mm4wBPw4PB40mi2 4P6","st_dist_04":"iiL R4iwi4y wim6gN0mik0B","st_dist_05":"kNg0 RBkw6wP NLiRBm2Bg2","st_dist_06":"g4BL40PiBNP0m2040B2wi6ym","st_dist_07":"LLkgkggg0N2kPm Nk46RPkBw","st_dist_08":"N wmwkyNmw2Bgy0Liy4iL42N","st_dist_09":"kyNN4NB0RP46yg262y42RN0B","st_dist_10":"Ng4kP6RkyLg6wBwPm22Nmgig","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mi22mkmim Rmk m6BgPPg4iB2RP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":97,"st_w_id":1,"st_quantity":19,"st_dist_01":"kB0mBRw2 iLmkLRLkByky yN","st_dist_02":"LyRRRN6g2iyg 66 yL0w4 y","st_dist_03":"B4wP42PR40 B40 6y6kBiw L","st_dist_04":"mR042k06R4R0 yRP4g0Bw4im","st_dist_05":"0N mk6RNRiLB Nww0BBgBy20","st_dist_06":" 6wPPP4kw26Ni40NLmPkLR4N","st_dist_07":"Ly24ymwkmPNmmL2miP gRB2","st_dist_08":"2mg B6 kk6Pg6RRPm6ym0R","st_dist_09":"R y6B6Bgk Rkig gPRm2NL6B","st_dist_10":" iyBim4046g6i0k6N 4ywLN0","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"PNB440wB6wgBBNNR4m0PBBNkgBLgwk6ww00iy"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":98,"st_w_id":1,"st_quantity":63,"st_dist_01":"y 2m0LikNNLyy6k0N4LN0LkL","st_dist_02":"LB6N i2R6yL6m0mkg442wi6","st_dist_03":"66ggykgLkRy2w R24RNBPyw6","st_dist_04":"LmBgi4wmy4w066LP0g0iR2mB","st_dist_05":"iwy4 LByw6w2g 0w0LB0wkBk","st_dist_06":"gkBk24gwRBg0w4R0wig iyRB","st_dist_07":" gBR6kgmyBP242NPNm6kPLm0","st_dist_08":" k4NiL66Bimmi4R62Rw040w4","st_dist_09":"R00P0wyg4kBwL2m2 ikLg 2","st_dist_10":"mk4k mmk4LgiNL4LiBLiLw m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4LR442ywiiPyNPBPg0wR02w6gyLy406iN64N"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":99,"st_w_id":1,"st_quantity":39,"st_dist_01":"4NL R ii24kiNPNig4RLBL 4","st_dist_02":"0ikPL6L mgyk40gg4igL2mgw","st_dist_03":"wNwkNLgNk6BmL6wRgmy24ki4","st_dist_04":"Rk 6gwRLB4LPRByBRLP0 Lm4","st_dist_05":"NwiyBg4RiN ik NRkRyiw Bi","st_dist_06":"g4NBww R0 y6w6RiNRP 4Rg0","st_dist_07":"B20ygk 4BgBmwPy2 P04w66R","st_dist_08":"mBR20gRB06ykgNk mmPLRPyL","st_dist_09":"iR B4PP4yL2ig6yRN6yRmN0P","st_dist_10":"R0RmRNPN0LkN kiRmmwR k6","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"mL4mNkR6m6LPR PBkg NPikBi0P m 60Li igi0L44y4m2kkky"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":null,"after":{"st_i_id":100,"st_w_id":1,"st_quantity":100,"st_dist_01":"m2BLPRB6m i664k0ikwRPgi6","st_dist_02":"0yN264Lg4R2m0RR2kP0L4yN","st_dist_03":"6N6g 44m202gBi2g2wR02 wi","st_dist_04":" i wNg yRNLg2mRNkNNi64ky","st_dist_05":"NLN0NByNLPwmk6Bmkkyw6igi","st_dist_06":" 04BiPPmBwmRLR24B0m26i22","st_dist_07":"Py0 wP2m0LLLBg6kw RwLNRL","st_dist_08":"RwPmgmm64i2mBg6mNmm4Pgkm","st_dist_09":"mRL002i6BBN2mP LR6iyy0m","st_dist_10":"0iRyiBki0y6y 2N4Bii4N6Bw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"46k P0 y6Rm6iLRmgB4yw2gi ykNgkNgyyi20w6wPB6mB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081215,"snapshot":"true","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"stock","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081215,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":42,"st_w_id":1,"st_quantity":17,"st_dist_01":" NLB2i62LLmLgNwNmkBk44Lw","st_dist_02":"0w420By2wmgimLRP6 B2g 6R","st_dist_03":"Bg4L 0 6gwNB4Pg0mPmmwwB6","st_dist_04":"kw02PBmkywNiNBwRi k6L0kL","st_dist_05":"mPwi0026wg4g0B NNNNPP0g2","st_dist_06":"Rii6LkLPy6P2L 4g4PRgg 6m","st_dist_07":" BBmyBNB0R mLk0PN mkimPR","st_dist_08":"i060ymNy0yRy N6L2P6Bi2k6","st_dist_09":"0R NRRg4Pm R0BPB4gR6BNLL","st_dist_10":"yk6kwLR40i 2iPgPyPwygykw","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"046R BBy NmP6yg2iig 0iL4R4gLP"},"after":{"st_i_id":42,"st_w_id":1,"st_quantity":17,"st_dist_01":" NLB2i62LLmLgNwNmkBk44Lw","st_dist_02":"0w420By2wmgimLRP6 B2g 6R","st_dist_03":"Bg4L 0 6gwNB4Pg0mPmmwwB6","st_dist_04":"kw02PBmkywNiNBwRi k6L0kL","st_dist_05":"mPwi0026wg4g0B NNNNPP0g2","st_dist_06":"Rii6LkLPy6P2L 4g4PRgg 6m","st_dist_07":" BBmyBNB0R mLk0PN mkimPR","st_dist_08":"i060ymNy0yRy N6L2P6Bi2k6","st_dist_09":"0R NRRg4Pm R0BPB4gR6BNLL","st_dist_10":"yk6kwLR40i 2iPgPyPwygykw","st_ytd":5,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"046R BBy NmP6yg2iig 0iL4R4gLP"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24483272\"]","schema":"public","table":"stock","txId":1330,"lsn":24483272,"xmin":null},"op":"u","ts_ms":1664141081533,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":43,"st_w_id":1,"st_quantity":37,"st_dist_01":"PLi646NBw0Pg022LmNBy42wP","st_dist_02":"N406B446gL2mgwBPw0RL4gRg","st_dist_03":"B624i2P kmBy4PPRgLywBgg","st_dist_04":"gwkRgNRw20R4Bwgw46 PPig4","st_dist_05":"B2Ly2yi 0BRL6Pm2P RLBiRP","st_dist_06":"iP0Lk0kw4BBPk4m2gP24kg06","st_dist_07":"Pw6iwg L64 yyiyNB4yimi20","st_dist_08":"kmwkyNwiwygygN6yk6PLwL0N","st_dist_09":"iyN gPNg PiPLmmNN0 4wB","st_dist_10":"B0 g PyyRiNiw6wLLmBwL40w","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R20wB 0wBNwwBNNm4Pk6g2iP 2mR 4k2yi"},"after":{"st_i_id":43,"st_w_id":1,"st_quantity":37,"st_dist_01":"PLi646NBw0Pg022LmNBy42wP","st_dist_02":"N406B446gL2mgwBPw0RL4gRg","st_dist_03":"B624i2P kmBy4PPRgLywBgg","st_dist_04":"gwkRgNRw20R4Bwgw46 PPig4","st_dist_05":"B2Ly2yi 0BRL6Pm2P RLBiRP","st_dist_06":"iP0Lk0kw4BBPk4m2gP24kg06","st_dist_07":"Pw6iwg L64 yyiyNB4yimi20","st_dist_08":"kmwkyNwiwygygN6yk6PLwL0N","st_dist_09":"iyN gPNg PiPLmmNN0 4wB","st_dist_10":"B0 g PyyRiNiw6wLLmBwL40w","st_ytd":6,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"R20wB 0wBNwwBNNm4Pk6g2iP 2mR 4k2yi"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24489304\"]","schema":"public","table":"stock","txId":1330,"lsn":24489304,"xmin":null},"op":"u","ts_ms":1664141081533,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":44,"st_w_id":1,"st_quantity":10,"st_dist_01":"0Bw4PByBBg4PRiwLmwmkPN6P","st_dist_02":"g giRRwRyLiB0PyyBy0y40Bm","st_dist_03":"260PkNmL2w6NwP6R2Lw022L4","st_dist_04":"yNN kNyPgRm2wP4ky wgg6 N","st_dist_05":"iwL LNPNNgRkiR2LLykmLR2w","st_dist_06":" gm0kByk0BP iwRwwygNgkR6","st_dist_07":"wPy4Py BiPRgw6ByNwmkm6NL","st_dist_08":"mym0R6wky2RPkNNm BN6 0Bi","st_dist_09":"iywyk 62RB66wPgB2BP4wPL6","st_dist_10":"wm6NB6iLiNiB4wkLNyyN0ik4","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"BR6wg2gRBm0wg646L2RN i2L20RL"},"after":{"st_i_id":44,"st_w_id":1,"st_quantity":10,"st_dist_01":"0Bw4PByBBg4PRiwLmwmkPN6P","st_dist_02":"g giRRwRyLiB0PyyBy0y40Bm","st_dist_03":"260PkNmL2w6NwP6R2Lw022L4","st_dist_04":"yNN kNyPgRm2wP4ky wgg6 N","st_dist_05":"iwL LNPNNgRkiR2LLykmLR2w","st_dist_06":" gm0kByk0BP iwRwwygNgkR6","st_dist_07":"wPy4Py BiPRgw6ByNwmkm6NL","st_dist_08":"mym0R6wky2RPkNNm BN6 0Bi","st_dist_09":"iywyk 62RB66wPgB2BP4wPL6","st_dist_10":"wm6NB6iLiNiB4wkLNyyN0ik4","st_ytd":7,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"BR6wg2gRBm0wg646L2RN i2L20RL"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24490136\"]","schema":"public","table":"stock","txId":1330,"lsn":24490136,"xmin":null},"op":"u","ts_ms":1664141081533,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":45,"st_w_id":1,"st_quantity":84,"st_dist_01":"4RkwPk i0LPB66kymkiN6iNi","st_dist_02":" 2wBgw04RRRkiB040iy026mN","st_dist_03":" PP4RBNPRw26B0y2PBgN24m2","st_dist_04":"wRykP 2k64g40igmkB6gNk0","st_dist_05":"i24666Ri4ymmB 0w6g6Lg0g","st_dist_06":"L40gB gyBNBN66mmRyNL 42N","st_dist_07":"RL2kR4P6442w6w wPk6PPw R","st_dist_08":"wL2Pw4kBw00gB P2LL2R 62","st_dist_09":"2RLiNBg0 Pi2B4i6i6w00gwk","st_dist_10":"RP gg wBB 4R6 P02Rw0iRy","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"4BwkwR6kPRmy4BPRkRmg4iwi2yRgRyymP2NmiBgPw6LiN"},"after":{"st_i_id":45,"st_w_id":1,"st_quantity":84,"st_dist_01":"4RkwPk i0LPB66kymkiN6iNi","st_dist_02":" 2wBgw04RRRkiB040iy026mN","st_dist_03":" PP4RBNPRw26B0y2PBgN24m2","st_dist_04":"wRykP 2k64g40igmkB6gNk0","st_dist_05":"i24666Ri4ymmB 0w6g6Lg0g","st_dist_06":"L40gB gyBNBN66mmRyNL 42N","st_dist_07":"RL2kR4P6442w6w wPk6PPw R","st_dist_08":"wL2Pw4kBw00gB P2LL2R 62","st_dist_09":"2RLiNBg0 Pi2B4i6i6w00gwk","st_dist_10":"RP gg wBB 4R6 P02Rw0iRy","st_ytd":8,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"4BwkwR6kPRmy4BPRkRmg4iwi2yRgRyymP2NmiBgPw6LiN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24490952\"]","schema":"public","table":"stock","txId":1330,"lsn":24490952,"xmin":null},"op":"u","ts_ms":1664141081533,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":46,"st_w_id":1,"st_quantity":96,"st_dist_01":"Ni60gm 4y0NP404kRgNBRRmm","st_dist_02":"B06NLP2NiR 00iw6N PiBmwi","st_dist_03":" 00ywy6imiBgyB yL0BRmkR","st_dist_04":"NPy2yBmkyykNkgy20gN02NPB","st_dist_05":"NB44yiBLm2gL gNwRP06m04m","st_dist_06":" gggLwP0gPg i2 R2N k26gm","st_dist_07":"w64kkNiL04BPww2L6NRi 40w","st_dist_08":"Byw6NyP P2g62B mRNwkL6Pk","st_dist_09":"wk6PiiB 44wP6Bw0ygNwBwwi","st_dist_10":"0ggR4RyykPP wRLkgy 2mkg","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"yRR0mL02NiyR 2 i RmwB2ggm wkwByRR 6ygRmNN"},"after":{"st_i_id":46,"st_w_id":1,"st_quantity":96,"st_dist_01":"Ni60gm 4y0NP404kRgNBRRmm","st_dist_02":"B06NLP2NiR 00iw6N PiBmwi","st_dist_03":" 00ywy6imiBgyB yL0BRmkR","st_dist_04":"NPy2yBmkyykNkgy20gN02NPB","st_dist_05":"NB44yiBLm2gL gNwRP06m04m","st_dist_06":" gggLwP0gPg i2 R2N k26gm","st_dist_07":"w64kkNiL04BPww2L6NRi 40w","st_dist_08":"Byw6NyP P2g62B mRNwkL6Pk","st_dist_09":"wk6PiiB 44wP6Bw0ygNwBwwi","st_dist_10":"0ggR4RyykPP wRLkgy 2mkg","st_ytd":9,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"yRR0mL02NiyR 2 i RmwB2ggm wkwByRR 6ygRmNN"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081480,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24465088\",\"24491800\"]","schema":"public","table":"stock","txId":1330,"lsn":24491800,"xmin":null},"op":"u","ts_ms":1664141081533,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":47,"st_w_id":1,"st_quantity":81,"st_dist_01":"6PRgRmN6200PmmRy0 iwL46i","st_dist_02":" 0k6B6g0N2ikkB0NPLmB2LLN","st_dist_03":"gkRk0RNgLLyRy2N6L4 iBLiB","st_dist_04":"wwP wRyN24NyBBPP62gNgw N","st_dist_05":"NB 4N620wik24 6wL6Rwiw","st_dist_06":"PP2mimyB2Rm 2Rygkmy0iwBk","st_dist_07":"kmN6BNi4mmR PBi24kR0mP4L","st_dist_08":"Bg60 wmwkkyB402kP2 w4y0m","st_dist_09":"w 4BR60NNRNy 0BN04m2m4mL","st_dist_10":"L2 B06NkN6wLwN kPg L04g","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"iiPPRPPLPNN B0PgByg2626i0PNw2 wm"},"after":{"st_i_id":47,"st_w_id":1,"st_quantity":81,"st_dist_01":"6PRgRmN6200PmmRy0 iwL46i","st_dist_02":" 0k6B6g0N2ikkB0NPLmB2LLN","st_dist_03":"gkRk0RNgLLyRy2N6L4 iBLiB","st_dist_04":"wwP wRyN24NyBBPP62gNgw N","st_dist_05":"NB 4N620wik24 6wL6Rwiw","st_dist_06":"PP2mimyB2Rm 2Rygkmy0iwBk","st_dist_07":"kmN6BNi4mmR PBi24kR0mP4L","st_dist_08":"Bg60 wmwkkyB402kP2 w4y0m","st_dist_09":"w 4BR60NNRNy 0BN04m2m4mL","st_dist_10":"L2 B06NkN6wLwN kPg L04g","st_ytd":5,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"iiPPRPPLPNN B0PgByg2626i0PNw2 wm"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24502208\"]","schema":"public","table":"stock","txId":1331,"lsn":24502208,"xmin":null},"op":"u","ts_ms":1664141081535,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":48,"st_w_id":1,"st_quantity":91,"st_dist_01":"wB6gyk06iwkRLBRym66Rkk2m","st_dist_02":"62k4g6BNNBmm0B20i L2y2i2","st_dist_03":"gg0NwBgywB6Pg kBLRNimwkL","st_dist_04":"wNLL46NN0By4kgP0m0w4wLiN","st_dist_05":"m0iN2BR0iy6ygL06P RPPm w","st_dist_06":"NyRyRNPwNkPLy6i0 m kRyL6","st_dist_07":"RyLwRLyyLimRkL4yi2kmL44","st_dist_08":"w04giwy myRLBNkyNm LL6Bk","st_dist_09":"gRm06Ng4Rky0ByRy62ygRmmB","st_dist_10":"026LPg6BiwNLLLNP6PL2gyRP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"gyPgyk2gRkgRiy6Bi62 i 6 wBm0P2R Bi6Rg6gmkyLB6g4"},"after":{"st_i_id":48,"st_w_id":1,"st_quantity":91,"st_dist_01":"wB6gyk06iwkRLBRym66Rkk2m","st_dist_02":"62k4g6BNNBmm0B20i L2y2i2","st_dist_03":"gg0NwBgywB6Pg kBLRNimwkL","st_dist_04":"wNLL46NN0By4kgP0m0w4wLiN","st_dist_05":"m0iN2BR0iy6ygL06P RPPm w","st_dist_06":"NyRyRNPwNkPLy6i0 m kRyL6","st_dist_07":"RyLwRLyyLimRkL4yi2kmL44","st_dist_08":"w04giwy myRLBNkyNm LL6Bk","st_dist_09":"gRm06Ng4Rky0ByRy62ygRmmB","st_dist_10":"026LPg6BiwNLLLNP6PL2gyRP","st_ytd":6,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"gyPgyk2gRkgRiy6Bi62 i 6 wBm0P2R Bi6Rg6gmkyLB6g4"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24503056\"]","schema":"public","table":"stock","txId":1331,"lsn":24503056,"xmin":null},"op":"u","ts_ms":1664141081535,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":49,"st_w_id":1,"st_quantity":56,"st_dist_01":"P wBw2mwkL0k40PRy4m0g4ym","st_dist_02":"0L4 Rw2k0gPB4gy4gPBiLmm0","st_dist_03":"LLLPN0m6Pw 2gNRy2g266Nim","st_dist_04":" 0kikN6kBBwww2Bgi4ykLPw","st_dist_05":"2RLL0N RB0i2LPRwgRkmP6NR","st_dist_06":"yNm64RRyy02P6w40BPwmLBLw","st_dist_07":"BB22 RBk0m BLBLyBNwmkL60","st_dist_08":"BNL2RkmkgB46LB6RiRPPik g","st_dist_09":"kyP L62iNyyL2mw4Pi kPL4y","st_dist_10":"6BNRBNRmym4k400RR64R 0m","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"LmkByRmi0iN mymwiPiRk6wkg2mNkRkgwy6mwm4i6PL2P46"},"after":{"st_i_id":49,"st_w_id":1,"st_quantity":56,"st_dist_01":"P wBw2mwkL0k40PRy4m0g4ym","st_dist_02":"0L4 Rw2k0gPB4gy4gPBiLmm0","st_dist_03":"LLLPN0m6Pw 2gNRy2g266Nim","st_dist_04":" 0kikN6kBBwww2Bgi4ykLPw","st_dist_05":"2RLL0N RB0i2LPRwgRkmP6NR","st_dist_06":"yNm64RRyy02P6w40BPwmLBLw","st_dist_07":"BB22 RBk0m BLBLyBNwmkL60","st_dist_08":"BNL2RkmkgB46LB6RiRPPik g","st_dist_09":"kyP L62iNyyL2mw4Pi kPL4y","st_dist_10":"6BNRBNRmym4k400RR64R 0m","st_ytd":7,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"LmkByRmi0iN mymwiPiRk6wkg2mNkRkgwy6mwm4i6PL2P46"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24503912\"]","schema":"public","table":"stock","txId":1331,"lsn":24503912,"xmin":null},"op":"u","ts_ms":1664141081535,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":50,"st_w_id":1,"st_quantity":76,"st_dist_01":"N6Pi6kmBPwyR6imBBm0wkPgi","st_dist_02":"4Ry wRPP6kkRN6 Nw 4LN4k0","st_dist_03":"wP6NmR iyPByy60 gwPig Pk","st_dist_04":"0LNLB64Ly2 m mRgBPP4B00w","st_dist_05":" 20gwyPwR02LPkw26N6w g44","st_dist_06":"R0g62m0LNLmmRPkLLRNB 2gy","st_dist_07":"4yBP6P2Ly PkNw2B kmP00R","st_dist_08":"iR40Rm6PPw0P Nkmk64Ly62","st_dist_09":"BNwim2yBk44P yik4ww60 Ly","st_dist_10":"RLN B4Lim kN migLwN2my6g","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"R g LR2w2RyPmR60imRBBg6PB6wywLB"},"after":{"st_i_id":50,"st_w_id":1,"st_quantity":76,"st_dist_01":"N6Pi6kmBPwyR6imBBm0wkPgi","st_dist_02":"4Ry wRPP6kkRN6 Nw 4LN4k0","st_dist_03":"wP6NmR iyPByy60 gwPig Pk","st_dist_04":"0LNLB64Ly2 m mRgBPP4B00w","st_dist_05":" 20gwyPwR02LPkw26N6w g44","st_dist_06":"R0g62m0LNLmmRPkLLRNB 2gy","st_dist_07":"4yBP6P2Ly PkNw2B kmP00R","st_dist_08":"iR40Rm6PPw0P Nkmk64Ly62","st_dist_09":"BNwim2yBk44P yik4ww60 Ly","st_dist_10":"RLN B4Lim kN migLwN2my6g","st_ytd":8,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"R g LR2w2RyPmR60imRBBg6PB6wywLB"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24504760\"]","schema":"public","table":"stock","txId":1331,"lsn":24504760,"xmin":null},"op":"u","ts_ms":1664141081535,"transaction":null}} -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"st_i_id"},{"type":"int32","optional":false,"field":"st_w_id"},{"type":"int32","optional":true,"field":"st_quantity"},{"type":"string","optional":true,"field":"st_dist_01"},{"type":"string","optional":true,"field":"st_dist_02"},{"type":"string","optional":true,"field":"st_dist_03"},{"type":"string","optional":true,"field":"st_dist_04"},{"type":"string","optional":true,"field":"st_dist_05"},{"type":"string","optional":true,"field":"st_dist_06"},{"type":"string","optional":true,"field":"st_dist_07"},{"type":"string","optional":true,"field":"st_dist_08"},{"type":"string","optional":true,"field":"st_dist_09"},{"type":"string","optional":true,"field":"st_dist_10"},{"type":"int32","optional":true,"field":"st_ytd"},{"type":"int32","optional":true,"field":"st_order_cnt"},{"type":"int32","optional":true,"field":"st_remote_cnt"},{"type":"string","optional":true,"field":"st_data"}],"optional":true,"name":"postgres.public.stock.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.stock.Envelope"},"payload":{"before":{"st_i_id":51,"st_w_id":1,"st_quantity":60,"st_dist_01":"BmBg6BiNyLmLi2Ng4kBR0ww6","st_dist_02":" PmPgwLyk 4mRRPR0 k2NPi","st_dist_03":"iRkyy2Pk 2ig6iPLB2 LRimi","st_dist_04":"Lyk0i 2LNNiiR LP6k LkgyP","st_dist_05":"kBLiL0PPPykmPPPB6NimwP w","st_dist_06":"R4y0NgN0m4m42wR0LwyLLLiy","st_dist_07":"i 0i4mRB6N6ggBy 0L02RRLi","st_dist_08":" yyiw62mw 60RimkyB0mN0iw","st_dist_09":"k4yiPwgBNimg4L42m6yRk44L","st_dist_10":"wLwPRBgRw2NwNP0 iNL0giRP","st_ytd":0,"st_order_cnt":0,"st_remote_cnt":0,"st_data":"6RNmRNgNRiy6PPmgkLR BPiNPPN2m2RyL k 4ym4LL04"},"after":{"st_i_id":51,"st_w_id":1,"st_quantity":60,"st_dist_01":"BmBg6BiNyLmLi2Ng4kBR0ww6","st_dist_02":" PmPgwLyk 4mRRPR0 k2NPi","st_dist_03":"iRkyy2Pk 2ig6iPLB2 LRimi","st_dist_04":"Lyk0i 2LNNiiR LP6k LkgyP","st_dist_05":"kBLiL0PPPykmPPPB6NimwP w","st_dist_06":"R4y0NgN0m4m42wR0LwyLLLiy","st_dist_07":"i 0i4mRB6N6ggBy 0L02RRLi","st_dist_08":" yyiw62mw 60RimkyB0mN0iw","st_dist_09":"k4yiPwgBNimg4L42m6yRk44L","st_dist_10":"wLwPRBgRw2NwNP0 iNL0giRP","st_ytd":9,"st_order_cnt":1,"st_remote_cnt":1,"st_data":"6RNmRNgNRiy6PPmgkLR BPiNPPN2m2RyL k 4ym4LL04"},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081483,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"24492632\",\"24505584\"]","schema":"public","table":"stock","txId":1331,"lsn":24505584,"xmin":null},"op":"u","ts_ms":1664141081536,"transaction":null}} diff --git a/scripts/source/test_data/tpcc_warehouse.1 b/scripts/source/test_data/tpcc_warehouse.1 deleted file mode 100644 index c1d9471d1a99b..0000000000000 --- a/scripts/source/test_data/tpcc_warehouse.1 +++ /dev/null @@ -1 +0,0 @@ -{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":null,"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585362.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1664141081219,"snapshot":"last","db":"ch_benchmark_db","sequence":"[null,\"24363832\"]","schema":"public","table":"warehouse","txId":1324,"lsn":24363832,"xmin":null},"op":"r","ts_ms":1664141081219,"transaction":null}} diff --git a/scripts/source/test_data/warehouse.1 b/scripts/source/test_data/warehouse.1 new file mode 100644 index 0000000000000..6f87ee8b9af3b --- /dev/null +++ b/scripts/source/test_data/warehouse.1 @@ -0,0 +1,51 @@ +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":null,"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585362.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511739252,"snapshot":"last","db":"ch_benchmark_db","sequence":"[null,\"25502800\"]","schema":"public","table":"warehouse","txId":4498,"lsn":25502800,"xmin":null},"op":"r","ts_ms":1665511739252,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585362.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585404.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743599,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25806768\",\"25806768\"]","schema":"public","table":"warehouse","txId":4529,"lsn":25806768,"xmin":null},"op":"u","ts_ms":1665511743606,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585404.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585446.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743607,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25816784\",\"25816784\"]","schema":"public","table":"warehouse","txId":4530,"lsn":25816784,"xmin":null},"op":"u","ts_ms":1665511743611,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585446.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585488.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743617,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25818776\",\"25818776\"]","schema":"public","table":"warehouse","txId":4531,"lsn":25818776,"xmin":null},"op":"u","ts_ms":1665511743620,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585488.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585530.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743625,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25828544\",\"25828544\"]","schema":"public","table":"warehouse","txId":4532,"lsn":25828544,"xmin":null},"op":"u","ts_ms":1665511743628,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585530.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585572.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743636,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25838640\",\"25838640\"]","schema":"public","table":"warehouse","txId":4533,"lsn":25838640,"xmin":null},"op":"u","ts_ms":1665511743639,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585572.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585614.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743645,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25840304\",\"25840304\"]","schema":"public","table":"warehouse","txId":4534,"lsn":25840304,"xmin":null},"op":"u","ts_ms":1665511743649,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585614.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585656.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743655,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25841968\",\"25841968\"]","schema":"public","table":"warehouse","txId":4535,"lsn":25841968,"xmin":null},"op":"u","ts_ms":1665511743658,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585656.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585698.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743663,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25843904\",\"25843904\"]","schema":"public","table":"warehouse","txId":4536,"lsn":25843904,"xmin":null},"op":"u","ts_ms":1665511743666,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585698.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585740.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743670,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25845904\",\"25845904\"]","schema":"public","table":"warehouse","txId":4537,"lsn":25845904,"xmin":null},"op":"u","ts_ms":1665511743674,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585740.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585782.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743680,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25847600\",\"25847600\"]","schema":"public","table":"warehouse","txId":4538,"lsn":25847600,"xmin":null},"op":"u","ts_ms":1665511743683,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585782.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585824.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743687,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25857080\",\"25857080\"]","schema":"public","table":"warehouse","txId":4539,"lsn":25857080,"xmin":null},"op":"u","ts_ms":1665511743691,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585824.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585866.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743696,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25858800\",\"25858800\"]","schema":"public","table":"warehouse","txId":4540,"lsn":25858800,"xmin":null},"op":"u","ts_ms":1665511743699,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585866.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585908.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743703,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25860736\",\"25860736\"]","schema":"public","table":"warehouse","txId":4541,"lsn":25860736,"xmin":null},"op":"u","ts_ms":1665511743706,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585908.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585950.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743710,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25862664\",\"25862664\"]","schema":"public","table":"warehouse","txId":4542,"lsn":25862664,"xmin":null},"op":"u","ts_ms":1665511743713,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585950.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585992.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743717,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25864512\",\"25864512\"]","schema":"public","table":"warehouse","txId":4543,"lsn":25864512,"xmin":null},"op":"u","ts_ms":1665511743720,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":585992.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586034.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743727,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25866240\",\"25866240\"]","schema":"public","table":"warehouse","txId":4544,"lsn":25866240,"xmin":null},"op":"u","ts_ms":1665511743730,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586034.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586076.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743735,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25867968\",\"25867968\"]","schema":"public","table":"warehouse","txId":4545,"lsn":25867968,"xmin":null},"op":"u","ts_ms":1665511743738,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586076.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586118.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743742,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25869904\",\"25869904\"]","schema":"public","table":"warehouse","txId":4546,"lsn":25869904,"xmin":null},"op":"u","ts_ms":1665511743746,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586118.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586160.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743750,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25871968\",\"25871968\"]","schema":"public","table":"warehouse","txId":4547,"lsn":25871968,"xmin":null},"op":"u","ts_ms":1665511743753,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586160.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586202.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743757,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25873664\",\"25873664\"]","schema":"public","table":"warehouse","txId":4548,"lsn":25873664,"xmin":null},"op":"u","ts_ms":1665511743760,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586202.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586244.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743764,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25874848\",\"25874848\"]","schema":"public","table":"warehouse","txId":4549,"lsn":25874848,"xmin":null},"op":"u","ts_ms":1665511743767,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586244.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586286.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743771,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25876504\",\"25876504\"]","schema":"public","table":"warehouse","txId":4550,"lsn":25876504,"xmin":null},"op":"u","ts_ms":1665511743774,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586286.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586328.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743779,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25878504\",\"25878504\"]","schema":"public","table":"warehouse","txId":4551,"lsn":25878504,"xmin":null},"op":"u","ts_ms":1665511743782,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586328.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586370.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743786,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25880376\",\"25880376\"]","schema":"public","table":"warehouse","txId":4552,"lsn":25880376,"xmin":null},"op":"u","ts_ms":1665511743788,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586370.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586412.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743816,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25882168\",\"25882168\"]","schema":"public","table":"warehouse","txId":4553,"lsn":25882168,"xmin":null},"op":"u","ts_ms":1665511743818,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586412.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586454.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743824,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25883896\",\"25883896\"]","schema":"public","table":"warehouse","txId":4554,"lsn":25883896,"xmin":null},"op":"u","ts_ms":1665511743827,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586454.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586496.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743832,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25885624\",\"25885624\"]","schema":"public","table":"warehouse","txId":4555,"lsn":25885624,"xmin":null},"op":"u","ts_ms":1665511743835,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586496.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586538.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743838,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25887584\",\"25887584\"]","schema":"public","table":"warehouse","txId":4556,"lsn":25887584,"xmin":null},"op":"u","ts_ms":1665511743841,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586538.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586580.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743846,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25889624\",\"25889624\"]","schema":"public","table":"warehouse","txId":4557,"lsn":25889624,"xmin":null},"op":"u","ts_ms":1665511743849,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586580.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586622.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743852,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25891320\",\"25891320\"]","schema":"public","table":"warehouse","txId":4558,"lsn":25891320,"xmin":null},"op":"u","ts_ms":1665511743855,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586622.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586664.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743860,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25892504\",\"25892504\"]","schema":"public","table":"warehouse","txId":4559,"lsn":25892504,"xmin":null},"op":"u","ts_ms":1665511743863,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586664.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586706.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743868,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25894320\",\"25894320\"]","schema":"public","table":"warehouse","txId":4560,"lsn":25894320,"xmin":null},"op":"u","ts_ms":1665511743871,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586706.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586748.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743875,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25896344\",\"25896344\"]","schema":"public","table":"warehouse","txId":4561,"lsn":25896344,"xmin":null},"op":"u","ts_ms":1665511743879,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586748.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586790.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743883,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25898192\",\"25898192\"]","schema":"public","table":"warehouse","txId":4562,"lsn":25898192,"xmin":null},"op":"u","ts_ms":1665511743886,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586790.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586832.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743890,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25899984\",\"25899984\"]","schema":"public","table":"warehouse","txId":4563,"lsn":25899984,"xmin":null},"op":"u","ts_ms":1665511743893,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586832.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586874.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743897,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25901712\",\"25901712\"]","schema":"public","table":"warehouse","txId":4564,"lsn":25901712,"xmin":null},"op":"u","ts_ms":1665511743900,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586874.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586916.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743905,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25903464\",\"25903464\"]","schema":"public","table":"warehouse","txId":4565,"lsn":25903464,"xmin":null},"op":"u","ts_ms":1665511743908,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586916.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586958.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743915,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25905400\",\"25905400\"]","schema":"public","table":"warehouse","txId":4566,"lsn":25905400,"xmin":null},"op":"u","ts_ms":1665511743920,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":586958.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587000.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743926,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25907440\",\"25907440\"]","schema":"public","table":"warehouse","txId":4567,"lsn":25907440,"xmin":null},"op":"u","ts_ms":1665511743932,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587000.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587042.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743938,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25909136\",\"25909136\"]","schema":"public","table":"warehouse","txId":4568,"lsn":25909136,"xmin":null},"op":"u","ts_ms":1665511743941,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587042.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587084.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743946,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25910320\",\"25910320\"]","schema":"public","table":"warehouse","txId":4569,"lsn":25910320,"xmin":null},"op":"u","ts_ms":1665511743949,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587084.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587126.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743954,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25912000\",\"25912000\"]","schema":"public","table":"warehouse","txId":4570,"lsn":25912000,"xmin":null},"op":"u","ts_ms":1665511743957,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587126.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587168.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743962,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25914000\",\"25914000\"]","schema":"public","table":"warehouse","txId":4571,"lsn":25914000,"xmin":null},"op":"u","ts_ms":1665511743965,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587168.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587210.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743969,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25915848\",\"25915848\"]","schema":"public","table":"warehouse","txId":4572,"lsn":25915848,"xmin":null},"op":"u","ts_ms":1665511743972,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587210.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587252.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743976,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25917640\",\"25917640\"]","schema":"public","table":"warehouse","txId":4573,"lsn":25917640,"xmin":null},"op":"u","ts_ms":1665511743979,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587252.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587294.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743983,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25919368\",\"25919368\"]","schema":"public","table":"warehouse","txId":4574,"lsn":25919368,"xmin":null},"op":"u","ts_ms":1665511743989,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587294.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587336.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511743995,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25921120\",\"25921120\"]","schema":"public","table":"warehouse","txId":4575,"lsn":25921120,"xmin":null},"op":"u","ts_ms":1665511743999,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587336.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587378.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744003,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25923056\",\"25923056\"]","schema":"public","table":"warehouse","txId":4576,"lsn":25923056,"xmin":null},"op":"u","ts_ms":1665511744006,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587378.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587420.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744010,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25925096\",\"25925096\"]","schema":"public","table":"warehouse","txId":4577,"lsn":25925096,"xmin":null},"op":"u","ts_ms":1665511744013,"transaction":null}} +{"schema":{"type":"struct","fields":[{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"before"},{"type":"struct","fields":[{"type":"int32","optional":false,"field":"w_id"},{"type":"string","optional":true,"field":"w_name"},{"type":"string","optional":true,"field":"w_street_1"},{"type":"string","optional":true,"field":"w_street_2"},{"type":"string","optional":true,"field":"w_city"},{"type":"string","optional":true,"field":"w_state"},{"type":"string","optional":true,"field":"w_zip"},{"type":"float","optional":true,"field":"w_tax"},{"type":"float","optional":true,"field":"w_ytd"}],"optional":true,"name":"postgres.public.warehouse.Value","field":"after"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"version"},{"type":"string","optional":false,"field":"connector"},{"type":"string","optional":false,"field":"name"},{"type":"int64","optional":false,"field":"ts_ms"},{"type":"string","optional":true,"name":"io.debezium.data.Enum","version":1,"parameters":{"allowed":"true,last,false,incremental"},"default":"false","field":"snapshot"},{"type":"string","optional":false,"field":"db"},{"type":"string","optional":true,"field":"sequence"},{"type":"string","optional":false,"field":"schema"},{"type":"string","optional":false,"field":"table"},{"type":"int64","optional":true,"field":"txId"},{"type":"int64","optional":true,"field":"lsn"},{"type":"int64","optional":true,"field":"xmin"}],"optional":false,"name":"io.debezium.connector.postgresql.Source","field":"source"},{"type":"string","optional":false,"field":"op"},{"type":"int64","optional":true,"field":"ts_ms"},{"type":"struct","fields":[{"type":"string","optional":false,"field":"id"},{"type":"int64","optional":false,"field":"total_order"},{"type":"int64","optional":false,"field":"data_collection_order"}],"optional":true,"field":"transaction"}],"optional":false,"name":"postgres.public.warehouse.Envelope"},"payload":{"before":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587420.0},"after":{"w_id":1,"w_name":"mwLkm4","w_street_1":"N20BRLw P6g06PN2Lm4i","w_street_2":" kR ggN PkkkL","w_city":"Pw 0Rii4kNL4ggLgR","w_state":"mR","w_zip":"718311111","w_tax":0.0356,"w_ytd":587462.0},"source":{"version":"1.9.5.Final","connector":"postgresql","name":"postgres","ts_ms":1665511744018,"snapshot":"false","db":"ch_benchmark_db","sequence":"[\"25926792\",\"25926792\"]","schema":"public","table":"warehouse","txId":4578,"lsn":25926792,"xmin":null},"op":"u","ts_ms":1665511744020,"transaction":null}}